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

abbreviate(String, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
convert "From src insert blah blah" to "From src insert ...
absolute(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
AbstractPrimitiveJavaObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
An AbstractJavaPrimitiveObjectInspector for a Java object.
AbstractPrimitiveJavaObjectInspector(PrimitiveObjectInspectorUtils.PrimitiveTypeEntry) - 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(PrimitiveObjectInspectorUtils.PrimitiveTypeEntry) - 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(PrimitiveObjectInspectorUtils.PrimitiveTypeEntry) - 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(PrimitiveObjectInspectorUtils.PrimitiveTypeEntry) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveWritableObjectInspector
 
accept(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask.QFileFilter
 
acceptsURL(String) - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
Checks whether a given url is in a valid format.
adaptor - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
add(TypeInfo) - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
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_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) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Add a partition to the table.
add_partitions(List<Partition>) - 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
 
addAlias(exprNodeDesc, String) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Adds the specified alias to the specified expr
addBatch() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
addBatch(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
addBatch() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
addBatch(String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
addBatch(String) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
addConvertedNode(exprNodeDesc, exprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
adds a replacement node for this expression
addDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
Add a dependent task on the current task.
addEntry(CacheEntry) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Add a CacheEntry.
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
addExpression(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
Add an expression
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)
addHasNonPartCols(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpWalkerCtx
 
addJoinOnExpression(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
Add an expression from the JOIN condition.
addListener(CachePolicyListener) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.CachePolicy
Add a listener to this cache policy.
addListener(CachePolicyListener) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Add a listener to this cache policy
addListener(CachePolicyListener) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Adds the specified listener to this cache.
addMapWork(mapredWork, Table, String, Operator<?>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
addMapWork(String, String, Operator<?>, partitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
addOutputType(Class<?>) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
addPartition(Partition) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addPartition(Partition) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
AddPartitionDesc - Class in org.apache.hadoop.hive.ql.plan
Contains the information needed to add a partition.
AddPartitionDesc(String, String, Map<String, String>, String) - Constructor for class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
AddResourceProcessor - Class in org.apache.hadoop.hive.ql.processors
 
AddResourceProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
addTaskTmpDir(String) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
addToBucketCols(String) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
addToClassPath(ClassLoader, String[]) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Add new elements to the classpath
addToColNames(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
addToCols(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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
 
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
 
addToLString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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.drop_partition_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
addToPartitionKeys(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
addToSortCols(Order) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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(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_result
 
addToSuccess(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_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
 
addToValues(String) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
addTTDesc(tableDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
addWar(String, String) - Method in interface org.apache.hadoop.hive.shims.JettyShims.Server
 
addWrapper(String[]) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
Wrap the script in a wrapper that allows admins to control
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.
afterLast() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
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.
aggregationDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
aggregationIsDistinct - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
aggregationParameterFields - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
aggregationParameterObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
aggregationParameterObjects - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
aggregationParameterStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
aggregations - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
aggregationsParametersLastInvoke - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
aint - Variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
AINT - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
alias - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
alias - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
aliasList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
allProceduresAreCallable() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
allTablesAreSelectable() - Method in class org.apache.hadoop.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.
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_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) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
AlterHandler - Interface in org.apache.hadoop.hive.metastore
Interface for Alter Table and Alter Partition code
alterPartition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
alterPartition(String, String, Partition) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
alterStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixAddCol() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixAddPartitions() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixDropPartitions() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixRename() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixSerdeProperties() - 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) - 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.
alterTableDesc - Class in org.apache.hadoop.hive.ql.plan
 
alterTableDesc(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
alterTableDesc(String, List<FieldSchema>, alterTableDesc.alterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
alterTableDesc(alterTableDesc.alterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
alterTableDesc.alterTableTypes - Enum in org.apache.hadoop.hive.ql.plan
 
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>) - Constructor for exception org.apache.hadoop.hive.ql.exec.AmbiguousMethodException
Constructor.
AMPERSAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
AMPERSAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
analyze(ASTNode, Context) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.FunctionSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
append(Writable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
append a row of values.
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
 
appendPartition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
applySystemProperties() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
areAllParentsInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Operator
checks whether all parent operators are initialized or not
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
ASTPartitionPruner - Class in org.apache.hadoop.hive.ql.parse
 
ASTPartitionPruner() - Constructor for class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
 
ASTPartitionPruner(String, QBMetaData, HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
Creates a new instance of PartitionPruner
aString - Variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
ASTRING - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.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
 
AUTO_COMMIT - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Option to automatically commit data after each operation.
autoCommitFailureClosesAllResultSets() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
autoDelete - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
auxJars - Variable in class org.apache.hadoop.hive.conf.HiveConf
 
available() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream

B

backup(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
BaseRecordManager - Class in org.apache.hadoop.hive.ql.util.jdbm.recman
This class manages records, which are uninterpreted blobs of data.
BaseRecordManager(String) - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Creates a record manager for the indicated file
BaseSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
 
BaseSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
BaseSemanticAnalyzer.tableSpec - Class in org.apache.hadoop.hive.ql.parse
 
BaseSemanticAnalyzer.tableSpec(Hive, HiveConf, ASTNode) - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
beforeFirst() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
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.
BeginToken() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
BIGINT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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
 
bis - Variable in class org.apache.hadoop.hive.serde2.ByteStreamTypedSerDe
 
bis_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
BITWISEOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
BITWISEOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
BITWISEXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
BITWISEXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
BLOCK - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Magic for blocks.
block - Variable in class org.apache.hadoop.hive.ql.util.jdbm.recman.PageHeader
 
BLOCK_SIZE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.recman.RecordFile
The length of a single block.
BlockIo - Class in org.apache.hadoop.hive.ql.util.jdbm.recman
This class wraps a page-sized byte array and provides methods to read and write data to and from it.
BlockIo() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Default constructor for serialization
BlockView - Interface in org.apache.hadoop.hive.ql.util.jdbm.recman
This is a marker interface that is implemented by classes that interpret blocks of data by pretending to be an overlay.
body() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
BOOLEAN_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
BooleanObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A BooleanObjectInspector inspects an Object representing a Boolean.
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
 
bos - Variable in class org.apache.hadoop.hive.serde2.ByteStreamTypedSerDe
 
bos_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
BUCKET_COUNT - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
BUCKET_FIELD_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
BUCKETCOLS - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
bufcolumn - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
buffer - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
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
 
ByteArrayComparator - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Comparator for byte arrays.
ByteArrayComparator() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.ByteArrayComparator
 
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
 
ByteArraySerializer - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Serializer for byte arrays -- simple returns the byte array itself.
ByteArraySerializer() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.ByteArraySerializer
 
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.
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.serde2.lazy.LazyNonPrimitive
 
bytes - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
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.
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
 
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
 
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
 
ByteStreamTypedSerDe - Class in org.apache.hadoop.hive.serde2
 
ByteStreamTypedSerDe(Type) - Constructor for class org.apache.hadoop.hive.serde2.ByteStreamTypedSerDe
 
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
 
ByteWritable - Class in org.apache.hadoop.hive.ql.exec
 
ByteWritable(int) - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable
 
ByteWritable() - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable
 
byteWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
 
byteWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
byteWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
ByteWritable - Class in org.apache.hadoop.hive.serde2.io
 
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
A Comparator optimized for BytesWritable.
ByteWritable.Comparator() - Constructor for class org.apache.hadoop.hive.ql.exec.ByteWritable.Comparator
 
ByteWritable.Comparator - Class in org.apache.hadoop.hive.serde2.io
A Comparator optimized for BytesWritable.
ByteWritable.Comparator() - Constructor for class org.apache.hadoop.hive.serde2.io.ByteWritable.Comparator
 

C

CACHE_SIZE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Cache size (when applicable)
CACHE_TYPE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Cache type.
CacheEvictionException - Exception in org.apache.hadoop.hive.ql.util.jdbm.helper
Exception that occurs during eviction of an object in the cache.
CacheEvictionException(Exception) - Constructor for exception org.apache.hadoop.hive.ql.util.jdbm.helper.CacheEvictionException
 
cacheObjectEvicted(Object) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.CachePolicyListener
Notification that the cache this listener is attached to is evicting the object indicated.
CachePolicy - Interface in org.apache.hadoop.hive.ql.util.jdbm.helper
CachePolicity is an abstraction for different cache policies.
CachePolicyListener - Interface in org.apache.hadoop.hive.ql.util.jdbm.helper
Callback interface between CachePolicy and a Cache implementation to notify about cached object eviction.
CacheRecordManager - Class in org.apache.hadoop.hive.ql.util.jdbm.recman
A RecordManager wrapping and caching another RecordManager.
CacheRecordManager(RecordManager, CachePolicy) - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Construct a CacheRecordManager wrapping another RecordManager and using a given cache policy.
cancel() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
cancel() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
cancel() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
cancelRowUpdates() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
caseExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
castExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
CharSetLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
CharSetLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
CharSetName - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
CharSetName - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
checkAndGenObject() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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
checkMetastore(String, String, List<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.
checkObjectByteInfo(ObjectInspector, byte[], int, LazyBinaryUtils.RecordInfo) - 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.
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
 
checkValidity() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
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
 
children - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
childTasks - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
className - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
clear() - Method in class org.apache.hadoop.hive.ql.Context
 
clear() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Removes all elements.
clearBatch() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
clearBatch() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
clearBatch() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
clearFetchContext() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Clear the context, if anything needs to be done.
clearMapRedWork(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
clearNodeScope(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
clearParameters() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
clearParameters() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
clearWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
clearWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
clearWarnings() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
clearWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
clearWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
CliDriver - Class in org.apache.hadoop.hive.cli
 
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.
CliSessionState - Class in org.apache.hadoop.hive.cli
 
CliSessionState() - Constructor for class org.apache.hadoop.hive.cli.CliSessionState
 
CliSessionState(HiveConf) - Constructor for class org.apache.hadoop.hive.cli.CliSessionState
 
CliSessionState(HiveConf, Hive) - Constructor for class org.apache.hadoop.hive.cli.CliSessionState
 
clone() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
clone() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
clone() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
clone() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
clone() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
clone() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
clone() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
clone() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
clone() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeConstantDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeNullDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.partitionDesc
 
clone() - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
clone() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
clone() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
clone() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
clone() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
clone() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
clone() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
clone() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
close() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
close() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
close() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
close() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
close() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
close() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
close() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
close() - Method in class org.apache.hadoop.hive.ql.Driver
 
close() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapper
 
close() - Method in class org.apache.hadoop.hive.ql.exec.ExecReducer
 
close(boolean) - Method in interface org.apache.hadoop.hive.ql.exec.FileSinkOperator.RecordWriter
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
close() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
close(Reporter) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter
 
close() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
close(Reporter) - Method in class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat.IgnoreKeyWriter
Deprecated.  
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.Writer
 
close() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Closes the record manager.
close() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Closes the record manager.
close() - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Closes the record manager.
closeCurrent() - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
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
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
All done
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
We need to forward all the aggregations to children.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
close extra child operators that are initialized but are not executed.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Operator specific close routine.
clusterByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
clusterMode - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
cmdProperties - Variable in class org.apache.hadoop.hive.cli.CliSessionState
properties set from -hiveconf via cmdline
CodecPool - Class in org.apache.hadoop.hive.ql.io
A global compressor/decompressor pool used to save and reuse (possibly native) compression/decompression codecs.
CodecPool() - Constructor for class org.apache.hadoop.hive.ql.io.CodecPool
 
COL - Static variable in class org.apache.hadoop.hive.metastore.api.Order
 
col - Variable in class org.apache.hadoop.hive.serde2.ColumnSet
 
colExprMap - Variable in class org.apache.hadoop.hive.ql.exec.Operator
A map of output column name to input expression map.
collectDesc - Class in org.apache.hadoop.hive.ql.plan
 
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.Constants
 
CollectionTypes - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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
 
COLNAMES - Static variable in class org.apache.hadoop.hive.metastore.api.Index
 
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.serde2.SerDeUtils
 
COLS - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
colType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
column - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
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
 
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
 
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 ColumnarStruct.init(BytesRefArrayWritable cols), while LazyStruct parse fields in a lazy way.
ColumnarStruct(ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.columnar.ColumnarStruct
Construct a ColumnarStruct object with the TypeInfo.
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
 
columnName() - 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
 
columnNameType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameTypeList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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(HashMap<Operator<? extends Serializable>, OpParseContext>) - 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() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
 
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.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.ColumnPrunerReduceSinkProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Reduce Sink Operators.
ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc
 
ColumnPrunerProcFactory.ColumnPrunerSelectProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Select Operators.
ColumnPrunerProcFactory.ColumnPrunerSelectProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerSelectProc
 
ColumnPrunerProcFactory.ColumnPrunerTableScanProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Table Scan Operators.
ColumnPrunerProcFactory.ColumnPrunerTableScanProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerTableScanProc
 
columnRefOrder() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columns - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
For a single row, the split on the primary separator
COLUMNS_BUFFER_SIZE_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile.Writer
 
ColumnSet - Class in org.apache.hadoop.hive.serde2
 
ColumnSet() - Constructor for class org.apache.hadoop.hive.serde2.ColumnSet
 
ColumnSet(ArrayList<String>) - Constructor for class org.apache.hadoop.hive.serde2.ColumnSet
 
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.serde2.SerDeUtils
 
CommandProcessor - Interface in org.apache.hadoop.hive.ql.processors
 
CommandProcessorFactory - Class in org.apache.hadoop.hive.ql.processors
 
CommandProcessorFactory() - Constructor for class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
CommaOrSemicolon() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
COMMENT - Static variable in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
COMMENTS - Static variable in class org.apache.hadoop.hive.metastore.api.Version
 
commit() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
commit() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Commit (make persistent) all changes since beginning of transaction.
commit() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Commit (make persistent) all changes since beginning of transaction.
commit() - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Commit (make persistent) all changes since beginning of transaction.
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.
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.IntermediateObject - Class in org.apache.hadoop.hive.ql.exec
 
CommonJoinOperator.IntermediateObject(ArrayList<Object>[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.CommonJoinOperator.IntermediateObject
 
commonKey - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable.Comparator
Compare the buffers in serialized form.
compare(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask.MethodComparator
 
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, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.ByteArrayComparator
Compare two objects.
compare(Object, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.IntegerComparator
Compare two objects.
compare(Object, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.LongComparator
Compare two objects.
compare(Object, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.ObjectBAComparator
Compare two objects.
compare(Object, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.StringComparator
Compare two objects.
compare(Object, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.TransactionManager.BlockIoComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.io.ByteWritable.Comparator
Compare the buffers in serialized form.
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable.Comparator
 
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[], 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.
compareByteArray(byte[], byte[]) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.ByteArrayComparator
Compare two byte arrays.
compareByteArray(byte[], byte[]) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.ObjectBAComparator
Compare two byte arrays.
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.
compareText(Text, Text) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
We define this function here to make the code compatible between hadoop 0.17 and hadoop 0.20.
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
 
compareTo(Object) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Compares two ByteWritables.
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(Object) - Method in class org.apache.hadoop.hive.serde2.io.ByteWritable
Compares two ByteWritables.
compareTo(Object) - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
compareTo(Object) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
ComparisonOpMethodResolver - Class in org.apache.hadoop.hive.ql.exec
The class implements the method resolution for overloaded comparison operators.
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.
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>) - 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.
complexSplit(String, Pattern) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Split the line based on a complex regex pattern
COMPRESSED - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
computeValues(Object, List<ExprNodeEvaluator>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
Return the value as a standard object.
ConditionalResolver - Interface in org.apache.hadoop.hive.ql.plan
Conditional task resolution interface.
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
 
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
 
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() - 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.joinDesc
 
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.RCFileRecordReader
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
conf - Variable in class org.apache.hadoop.hive.ql.session.SessionState
current configuration
ConfigurableTProtocol - Interface in org.apache.hadoop.hive.serde2.thrift
An interface for TProtocols that need to have properties passed in to initialize them.
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapper
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.ExecReducer
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
connect(String, Properties) - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
 
console - Variable in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
console - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
console - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
console - Static variable in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
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
 
constant() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Constants - Class in org.apache.hadoop.hive.metastore.api
 
Constants() - Constructor for class org.apache.hadoop.hive.metastore.api.Constants
 
Constants - Class in org.apache.hadoop.hive.serde
 
Constants() - Constructor for class org.apache.hadoop.hive.serde.Constants
 
Constants - Class in org.apache.hadoop.hive.serde2.thrift.test
 
Constants() - Constructor for class org.apache.hadoop.hive.serde2.thrift.test.Constants
 
Constants - Class in org.apache.hadoop.hive.service
 
Constants() - Constructor for class org.apache.hadoop.hive.service.Constants
 
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
 
ConstValue() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
contains(BytesRefWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Returns true if this instance contains one or more the specified BytesRefWritable.
contentsEqual(InputStream, InputStream, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
Context - Class in org.apache.hadoop.hive.ql
Context for Semantic Analyzers.
Context() - Constructor for class org.apache.hadoop.hive.ql.Context
 
Context(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.Context
 
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.
Conversion - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Miscelaneous conversion utility methods.
Conversion() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
 
convert(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.Converter
 
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.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.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.TextConverter
 
convertIfNecessary(Object...) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.PrimitiveConversionHelper
 
convertIfNecessary(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Convert the return Object if necessary (when the ObjectInspectors of different possibilities are not all the same).
convertParameters(Method, List<exprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
convertPathToStringArray(List<Path>) - Static method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
convertPrimitiveToDouble(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Convert a primitive object to double.
convertStringToPathArray(List<String>) - Static method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
convertToByteArray(String) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Convert a string into a byte array.
convertToByteArray(byte) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Convert a byte into a byte array.
convertToByteArray(short) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Convert a short into a byte array.
convertToByteArray(int) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Convert an int into a byte array.
convertToByteArray(long) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Convert a long into a byte array.
convertToInt(byte[]) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Convert a byte array into an integer (signed 32-bit) value.
convertToLong(byte[]) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Convert a byte array into a long (signed 64-bit) value.
convertToString(byte[]) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Convert a byte array (encoded as UTF-8) into a String
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
 
copyFiles(Path, Path, FileSystem) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
copyFiles(Path) - Method in class org.apache.hadoop.hive.ql.metadata.Table
Inserts files specified into the partition.
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.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.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.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.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.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.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.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.
CopyTask - Class in org.apache.hadoop.hive.ql.exec
CopyTask implementation
CopyTask() - Constructor for class org.apache.hadoop.hive.ql.exec.CopyTask
 
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() - Constructor for class org.apache.hadoop.hive.ql.plan.copyWork
 
copyWork(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.copyWork
 
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.RuleRegExp
This function returns the cost of the rule for the specified stack.
countJobs(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.Driver
 
countJobs(List<Task<? extends Serializable>>, List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.Driver
 
countSel() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
countSelDi() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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(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(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(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(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(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_database(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_database(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_database(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_index(Index) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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_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
 
createArrayOf(String, Object[]) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createBlob() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createClob() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createColumnarStructInspector(List<String>, List<TypeInfo>, byte[], Text, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a hierarchical ObjectInspector for ColumnarStruct with the given columnNames and columnTypeInfos.
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.
createDatabase(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
createDatabase(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
createDatabase(Database) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
createDatabase(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
createDatabase(Database) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
createDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
createDatabase(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
createFilter(Operator, ExprWalkerInfo, OpWalkerInfo) - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
createFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
 
createFunctionDesc(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.createFunctionDesc
 
createFunctionStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createGenericUDAFEvaluator() - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
createInstance(RecordManager) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.htree.HTree
Create a persistent hashtable.
createKey() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
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.
createLazyObject(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a hierarchical LazyObject based on the given typeInfo.
createLazyObjectInspector(TypeInfo, byte[], int, Text, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyFactory
Create a hierarchical ObjectInspector for LazyObject with the given typeInfo.
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
Create a hierarchical ObjectInspector for LazyStruct with the given columnNames and columnTypeInfos.
createNClob() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createPartition(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates a partition.
createPartition(Table, Map<String, String>, Path) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates a partition
createRCFileWriter(JobConf, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Create a RCFile output stream based on job configuration Uses user supplied compression flag (rather than obtaining it from the Job Configuration)
createRecordManager(String, Properties) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.Provider
Create a default implementation record manager.
createRecordManager(String) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerFactory
Create a record manager.
createRecordManager(String, Properties) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerFactory
Create a record manager.
createRecordManager(String, Properties) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManagerProvider
Create a record manager.
CreateSequenceFile - Class in org.apache.hadoop.hive.serde2.thrift_test
 
CreateSequenceFile() - Constructor for class org.apache.hadoop.hive.serde2.thrift_test.CreateSequenceFile
 
CreateSequenceFile.ThriftSerializer - Class in org.apache.hadoop.hive.serde2.thrift_test
 
CreateSequenceFile.ThriftSerializer() - Constructor for class org.apache.hadoop.hive.serde2.thrift_test.CreateSequenceFile.ThriftSerializer
 
createSequenceWriter(JobConf, FileSystem, Path, Class<?>, Class<?>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Create a sequencefile output stream based on job configuration
createSequenceWriter(JobConf, FileSystem, Path, Class<?>, Class<?>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Create a sequencefile output stream based on job configuration Uses user supplied compression flag (rather than obtaining it from the Job Configuration)
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.
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.hadoop.hive.jdbc.HiveConnection
 
createStatement() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
Creates a Statement object for sending SQL statements to the database.
createStatement(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createStatement(int, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createStruct(String, Object[]) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createTable(Table) - 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 metdata and the directory for the table data
createTable(String, List<String>, List<String>, Class<? extends InputFormat>, Class<?>, int, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates a table metdata and the directory for the table data
createTable(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates the table with the give objects
createTable(Table, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Creates the table with the give objects
createTableDesc - Class in org.apache.hadoop.hive.ql.plan
 
createTableDesc(String, boolean, List<FieldSchema>, List<FieldSchema>, List<String>, List<Order>, int, String, String, String, String, String, String, String, String, String, String, Map<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.createTableDesc
 
createTableLikeDesc - Class in org.apache.hadoop.hive.ql.plan
 
createTableLikeDesc(String, boolean, String, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.plan.createTableLikeDesc
 
CREATETIME - Static variable in class org.apache.hadoop.hive.metastore.api.Partition
 
CREATETIME - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
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
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
ctrlaCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
ctx - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
curChar - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
 
currCount - Variable in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
currentKeyObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
currentKeys - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
currentToken - Variable in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
This is the last token that has been consumed successfully.
currentValueBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 

D

Database - Class in org.apache.hadoop.hive.metastore.api
 
Database() - Constructor for class org.apache.hadoop.hive.metastore.api.Database
 
Database(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.
dataDefinitionCausesTransactionCommit() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
dataDefinitionIgnoredInTransactions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
DATE_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
DATETIME_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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.session.SessionState
cached current connection to Hive MetaStore
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
DB_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
DBNAME - Static variable in class org.apache.hadoop.hive.metastore.api.Index
 
DBNAME - Static variable in class org.apache.hadoop.hive.metastore.api.Partition
 
DBNAME - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
DBNAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
DBNAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
DBNAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
ddlDesc - Class in org.apache.hadoop.hive.ql.plan
 
ddlDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ddlDesc
 
DDLSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
 
DDLSemanticAnalyzer(HiveConf) - 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() - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(alterTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(createTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(createTableLikeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(dropTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(descTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(showTablesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(showFunctionsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(descFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(showPartitionsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(AddPartitionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(MsckDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DEBUG - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Static debugging flag
debugStream - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Debug output.
DEFAULT - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
Lexical state.
DEFAULT_DATABASE_NAME - Static variable in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
defaultBoolVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
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
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
 
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.LazySimpleSerDe
 
DefaultSerializer - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Default java serializer.
DefaultSerializer() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.DefaultSerializer
Construct a DefaultSerializer.
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.
defaultVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
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
 
delete(long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Deletes a record.
delete(long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Deletes a record.
delete(long) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Deletes a record.
delete_resource(SessionState.ResourceType, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
delete_resource(SessionState.ResourceType) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
DELETEDATA - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
DELETEDATA - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
deleteDir(Path, boolean) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
DeleteResourceProcessor - Class in org.apache.hadoop.hive.ql.processors
 
DeleteResourceProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor
 
deleteRow() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
deletesAreDetected(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
deleteWHDirectory(Path, Configuration, boolean) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
desc - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeFieldEvaluator
 
descClass - Variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory.opTuple
 
descFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
DESCRIPTION - Static variable in class org.apache.hadoop.hive.metastore.api.Database
 
DESCRIPTION - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
description - Annotation Type in org.apache.hadoop.hive.ql.exec
 
descStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
descTableDesc - Class in org.apache.hadoop.hive.ql.plan
 
descTableDesc(Path, String, HashMap<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.descTableDesc
 
deserialize(byte[]) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.ByteArraySerializer
Deserialize the content of an object from a byte array.
deserialize(byte[]) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.DefaultSerializer
Deserialize the content of an object from a byte array.
deserialize(byte[]) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.IntegerSerializer
Deserialize the content of an object from a byte array.
deserialize(byte[]) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.LongSerializer
Deserialize the content of an object from a byte array.
deserialize(byte[]) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Serialization
Deserialize an object from a byte array
deserialize(byte[]) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.Serializer
Deserialize the content of an object from a byte array.
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.ColumnarSerDe
Deserialize a row from the Writable to a LazyObject.
deserialize(Writable) - Method in interface org.apache.hadoop.hive.serde2.Deserializer
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.lazy.LazySimpleSerDe
Deserialize a row from the Writable to a LazyObject.
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.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
 
deserializeCache - Variable in class org.apache.hadoop.hive.serde2.TypedSerDe
 
deserializeMapRedWork(InputStream, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
Deserializer - Interface in org.apache.hadoop.hive.serde2
HiveDeserializer is used to deserialize the data from hadoop Writable to a custom java object that can be of any type that the developer wants.
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
 
dfa17 - Variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DfsProcessor - Class in org.apache.hadoop.hive.ql.processors
 
DfsProcessor(Configuration) - Constructor for class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
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 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
 
disable_tracing() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Disable tracing.
DISABLE_TRANSACTIONS - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Option to disable transaction (to increase performance at the cost of potential data loss).
disableTransactions() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Switches off transactioning for the record manager.
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.
Dispatcher - Interface in org.apache.hadoop.hive.ql.lib
Dispatcher interface for Operators Used in operator graph walking to dispatch process/visitor functions for operators
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveParserX
 
distributeByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DIVIDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DIVIDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
doesMaxRowSizeIncludeBlobs() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
DOLLAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DOLLAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
doPhase1(ASTNode, QB, SemanticAnalyzer.Phase1Ctx) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
doPhase1QBExpr(ASTNode, QBExpr, String, String) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DOUBLE_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
DoubleObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A DoubleObjectInspector inspects an Object representing a Double.
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
 
doubleWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
doubleWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
doubleWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFOPDivide
 
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
 
DoubleWritable.Comparator - Class in org.apache.hadoop.hive.serde2.io
A Comparator optimized for DoubleWritable.
DoubleWritable.Comparator() - Constructor for class org.apache.hadoop.hive.serde2.io.DoubleWritable.Comparator
 
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() - Constructor for class org.apache.hadoop.hive.ql.Driver
 
drop_database(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_database(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_database(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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_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_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
 
dropDatabase(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropDatabase(String) - 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
 
dropFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
 
dropFunctionDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.dropFunctionDesc
 
dropFunctionStatement() - 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>, boolean) - 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>) - 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, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropTable(String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropTable(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropTable(String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropTable(String, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Drop the table.
dropTable(String, String, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Drop the table.
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, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops table along with the data in it.
dropTable(String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops the table.
dropTableDesc - Class in org.apache.hadoop.hive.ql.plan
 
dropTableDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.dropTableDesc
 
dropTableDesc(String, List<Map<String, String>>) - Constructor for class org.apache.hadoop.hive.ql.plan.dropTableDesc
 
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
 
dump(int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
dump(String) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
dumpHex() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Return the bytes in hex format.
dumpHex() - Method in class org.apache.hadoop.hive.serde2.binarysortable.OutputByteBuffer
Return the bytes in hex format.
DynamicSerDe - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
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(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(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(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
 
DynamicSerDeFieldType - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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

elementOffset - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.RecordInfo
 
elements() - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.CachePolicy
Enumerate through the objects currently in the cache.
elements() - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Enumerate elements' values in the cache
elements() - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Gets all the objects stored by the internal (L1) cache.
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
enable_tracing() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Enable tracing.
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.GroupByOperator
 
endGroup() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
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.
endQuery(String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Called at the end of Job.
endTask(String, Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Called at the end of a task.
enlargeArrays() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
Enlarge the size of arrays storing information for the elements inside the array.
ensureCapacity(int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
 
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
 
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 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 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
EQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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 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.Database
 
equals(Database) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
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.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 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.MetaException
 
equals(MetaException) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
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 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.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.StorageDescriptor
 
equals(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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.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.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_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.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_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.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_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_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.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_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_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_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_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.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_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_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_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_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_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_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_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_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_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_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.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.UnknownTableException
 
equals(UnknownTableException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
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.ql.exec.ByteWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
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.metadata.Dimension
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.TransactionManager.BlockIoComparator
 
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.ByteWritable
 
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable
Returns true iff o is a DoubleWritable with the same value.
equals(Object) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
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.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
Compare if 2 TypeInfos are the same.
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.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.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.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
 
err - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
ErrorMsg - Enum in org.apache.hadoop.hive.ql.parse
List of error messages thrown by the parser
ESCAPE_CHAR - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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.
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.
estimateNumberOfReducers(HiveConf, JobConf, mapredWork) - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
Estimate the number of reducers needed for this job, based on job input, and configuration parameters.
eval - Variable in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
eval - Variable in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeColumnEvaluator
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeConstantEvaluator
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
Evaluate the expression given the row.
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeFieldEvaluator
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeFuncEvaluator
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeNullEvaluator
 
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.GenericUDFCase
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFElt
 
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.GenericUDFIndex
 
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.GenericUDFLocate
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
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.GenericUDFWhen
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAbs
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAbs
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAbs
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAcos
Take Arc Cosine of a in radians.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFAscii
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFAsin
Take Arc Sine of a in radians.
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseCompare
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFBin
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFCeil
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFConcat
 
evaluate(Text, IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFConv
Convert numbers between different number bases.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFCos
Take Cosine of a
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFDate
Get the date part of a date time string.
evaluate(Text, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFDateAdd
Add a number of days to the date.
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFDateDiff
Calculate the difference in the number of days.
evaluate(Text, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFDateSub
Subtract a number of days to the date.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFDayOfMonth
Get the day of month from a date string.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFExp
Raise e (the base of natural logarithm) to the power of a.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFFloor
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
 
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(Text, Text) - 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(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFLike
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLn
Returns the natural logarithm of "a".
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Returns the natural logarithm of "a".
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog
Returns the logarithm of "a" with base "base".
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog10
Returns the logarithm of "a" with base 10.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFLog2
Returns the logarithm of "a" with base 2.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFLower
 
evaluate(Text, IntWritable, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFLpad
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFLTrim
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFMonth
Get the month from a date string.
evaluate(BooleanWritable, BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPAnd
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPDivide
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqual
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqual
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqual
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqual
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqual
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqual
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqual
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrGreaterThan
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrGreaterThan
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrGreaterThan
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrGreaterThan
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrGreaterThan
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrGreaterThan
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrGreaterThan
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrLessThan
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrLessThan
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrLessThan
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrLessThan
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrLessThan
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrLessThan
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrLessThan
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPGreaterThan
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPGreaterThan
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPGreaterThan
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPGreaterThan
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPGreaterThan
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPGreaterThan
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPGreaterThan
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLessThan
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLessThan
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLessThan
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLessThan
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLessThan
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLessThan
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLessThan
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPLongDivide
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMinus
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMinus
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMinus
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMinus
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMinus
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMinus
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMod
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMod
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMod
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMod
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMod
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMod
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMultiply
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMultiply
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMultiply
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMultiply
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMultiply
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPMultiply
 
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNegative
 
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNegative
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNegative
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNegative
 
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNegative
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNegative
 
evaluate(BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNot
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNotEqual
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNotEqual
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNotEqual
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNotEqual
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNotEqual
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNotEqual
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPNotEqual
 
evaluate(BooleanWritable, BooleanWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPOr
 
evaluate(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPlus
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPlus
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPlus
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPlus
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPlus
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPlus
 
evaluate(ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPositive
 
evaluate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPositive
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPositive
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPositive
 
evaluate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPositive
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFOPPositive
 
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(ByteWritable, ByteWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFPosMod
 
evaluate(ShortWritable, ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFPosMod
 
evaluate(IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFPosMod
 
evaluate(LongWritable, LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFPosMod
 
evaluate(FloatWritable, FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFPosMod
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFPosMod
 
evaluate(DoubleWritable, DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFPower
Raise a to the power of b.
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(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRound
 
evaluate(DoubleWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRound
 
evaluate(Text, IntWritable, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFRpad
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFRTrim
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSin
Take Sine of a.
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSpace
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSqrt
Return NULL for NULL or negative inputs; otherwise, return the square root.
evaluate(Text, IntWritable, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
evaluate(Text, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
evaluate(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(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(String) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDate
 
evaluate(Void) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDate
 
evaluate(Byte) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDate
 
evaluate(Short) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDate
 
evaluate(Integer) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDate
 
evaluate(Long) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDate
 
evaluate(Float) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDate
 
evaluate(Double) - Method in class org.apache.hadoop.hive.ql.udf.UDFToDate
 
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(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(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(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(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(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.UDFTrim
 
evaluate() - Method in class org.apache.hadoop.hive.ql.udf.UDFUnixTimeStamp
Return current UnixTime.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFUnixTimeStamp
Convert time string to UnixTime.
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFUnixTimeStamp
Convert time string to UnixTime with user defined pattern.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFUpper
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFYear
Get the year from a date string.
EX - Static variable in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
EX - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
EX - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
EX - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
EX - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
EX - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
EX - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
ExecDriver - Class in org.apache.hadoop.hive.ql.exec
 
ExecDriver() - Constructor for class org.apache.hadoop.hive.ql.exec.ExecDriver
Constructor when invoked from QL
ExecDriver(mapredWork, JobConf, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.ExecDriver
Constructor/Initialization for invocation as independent utility
ExecMapper - Class in org.apache.hadoop.hive.ql.exec
 
ExecMapper() - Constructor for class org.apache.hadoop.hive.ql.exec.ExecMapper
 
ExecMapper.reportStats - Class in org.apache.hadoop.hive.ql.exec
 
ExecMapper.reportStats(Reporter) - Constructor for class org.apache.hadoop.hive.ql.exec.ExecMapper.reportStats
 
ExecReducer - Class in org.apache.hadoop.hive.ql.exec
 
ExecReducer() - Constructor for class org.apache.hadoop.hive.ql.exec.ExecReducer
 
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.GetVersionPref
Executes the ant task .
execute() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
execute() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
execute(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
execute(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
execute(String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
execute(String, String[]) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
execute() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
execute(String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
execute(String, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
execute(String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
execute(String, String[]) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
execute(String) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
execute(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
execute(String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
execute(String, String[]) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
execute() - Method in class org.apache.hadoop.hive.ql.Driver
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.CopyTask
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
Execute a query plan using Hadoop
execute() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.MapRedTask
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
execute() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
execute(String) - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Executes a query.
execute(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
execute(String) - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
executeBatch() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
executeBatch() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeBatch() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
executeQuery() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
executeQuery(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
executeQuery() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeQuery(String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeQuery(String) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
executeUpdate() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
executeUpdate(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
executeUpdate(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
executeUpdate(String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
executeUpdate(String, String[]) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
executeUpdate() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeUpdate(String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeUpdate(String, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeUpdate(String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeUpdate(String, String[]) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeUpdate(String) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
executeUpdate(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
executeUpdate(String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
executeUpdate(String, String[]) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
exists(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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.
explain - Variable in class org.apache.hadoop.hive.ql.Context
 
explain - Annotation Type in org.apache.hadoop.hive.ql.plan
 
ExplainSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
 
ExplainSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
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
 
ExplainTask.MethodComparator() - Constructor for class org.apache.hadoop.hive.ql.exec.ExplainTask.MethodComparator
 
explainWork - Class in org.apache.hadoop.hive.ql.plan
 
explainWork() - Constructor for class org.apache.hadoop.hive.ql.plan.explainWork
 
explainWork(Path, List<Task<? extends Serializable>>, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.explainWork
 
explosionDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
expr - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeColumnEvaluator
 
expr - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeConstantEvaluator
 
expr - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeFuncEvaluator
 
expr - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
expr - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeNullEvaluator
 
expression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
expressionList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
exprNodeColumnDesc - Class in org.apache.hadoop.hive.ql.plan
 
exprNodeColumnDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
exprNodeColumnDesc(TypeInfo, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
exprNodeColumnDesc(Class<?>, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
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
 
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(exprNodeConstantDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeConstantEvaluator
 
exprNodeDesc - Class in org.apache.hadoop.hive.ql.plan
 
exprNodeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
exprNodeDesc(TypeInfo) - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
ExprNodeEvaluator - Class in org.apache.hadoop.hive.ql.exec
 
ExprNodeEvaluator() - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
 
ExprNodeEvaluatorFactory - Class in org.apache.hadoop.hive.ql.exec
 
ExprNodeEvaluatorFactory() - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorFactory
 
exprNodeFieldDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
exprNodeFuncDesc - Class in org.apache.hadoop.hive.ql.plan
The reason that we have to store UDFClass as well as UDFMethod is because UDFMethod might be declared in a parent class of UDFClass.
exprNodeFuncDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
exprNodeFuncDesc(String, TypeInfo, Class<? extends UDF>, Method, List<exprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
ExprNodeFuncEvaluator - Class in org.apache.hadoop.hive.ql.exec
 
ExprNodeFuncEvaluator(exprNodeFuncDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeFuncEvaluator
 
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, Class<? extends GenericUDF>, List<exprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
ExprNodeGenericFuncEvaluator - Class in org.apache.hadoop.hive.ql.exec
 
ExprNodeGenericFuncEvaluator(exprNodeGenericFuncDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
exprNodeNullDesc - Class in org.apache.hadoop.hive.ql.plan
 
exprNodeNullDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.exprNodeNullDesc
 
ExprNodeNullEvaluator - Class in org.apache.hadoop.hive.ql.exec
 
ExprNodeNullEvaluator(exprNodeNullDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeNullEvaluator
 
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.ppr
Expression processor factory for partition pruning.
ExprProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
 
ExprProcFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Processor for column expressions.
ExprProcFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.ColumnExprProcessor
 
ExprProcFactory.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Processor for constants and null expressions.
ExprProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.DefaultExprProcessor
 
ExprProcFactory.FieldExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.ppr
 
ExprProcFactory.FieldExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.FieldExprProcessor
 
ExprProcFactory.FuncExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Process function descriptors.
ExprProcFactory.FuncExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.FuncExprProcessor
 
ExprProcFactory.GenericFuncExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.ppr
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
ExprProcFactory.GenericFuncExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.GenericFuncExprProcessor
 
ExprPrunerInfo - Class in org.apache.hadoop.hive.ql.optimizer.ppr
The processor context for partition pruner.
ExprPrunerInfo() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprPrunerInfo
 
ExprWalkerInfo - Class in org.apache.hadoop.hive.ql.ppd
Context for Expression Walker for determining predicate pushdown candidates It contains a ExprInfo object for each expression that is processed.
ExprWalkerInfo() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
ExprWalkerInfo(Operator<? extends Serializable>, RowResolver) - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
ExprWalkerProcFactory - Class in org.apache.hadoop.hive.ql.ppd
Expression factory for predicate pushdown processing.
ExprWalkerProcFactory() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
ExprWalkerProcFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
 
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
 
ExprWalkerProcFactory.FieldExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.FieldExprProcessor
 
ExprWalkerProcFactory.FuncExprProcessor - 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.FuncExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.FuncExprProcessor
 
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
 
Extends() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
extractDesc - Class in org.apache.hadoop.hive.ql.plan
 
extractDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.extractDesc
 
extractDesc(exprNodeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.extractDesc
 
ExtractOperator - Class in org.apache.hadoop.hive.ql.exec
Extract operator implementation Extracts a subobject and passes that on.
ExtractOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
extractPushdownPreds(OpWalkerInfo, Operator<? extends Serializable>, exprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
extractPushdownPreds(OpWalkerInfo, Operator<? extends Serializable>, List<exprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
Extracts pushdown predicates from the given list of predicate expression

F

FastIterator - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Fast and simple iterator.
FastIterator() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.FastIterator
 
fetch(Vector<String>) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
fetch(Vector<String>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
fetch(long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Fetches a record using standard java object serialization.
fetch(long, Serializer) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Fetches a record using a custom serializer.
fetch(long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Fetches a record using standard Java serialization.
fetch(long, Serializer) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Fetches a record using a custom serializer.
fetch(long) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Fetches a record using standard java object serialization.
fetch(long, Serializer) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Fetches a record using a custom serializer.
fetchAll() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Fetches all the rows in a result set.
fetchAll() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
fetchAll() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
fetchN(int) - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Fetches numRows rows.
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() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Fetches the next row in a query result set.
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
 
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.parse.BaseSemanticAnalyzer
 
fetchTaskInit - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
fetchWork - Class in org.apache.hadoop.hive.ql.plan
 
fetchWork() - Constructor for class org.apache.hadoop.hive.ql.plan.fetchWork
 
fetchWork(String, tableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.fetchWork
 
fetchWork(String, tableDesc, int) - Constructor for class org.apache.hadoop.hive.ql.plan.fetchWork
 
fetchWork(List<String>, List<partitionDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.fetchWork
 
fetchWork(List<String>, List<partitionDesc>, int) - Constructor for class org.apache.hadoop.hive.ql.plan.fetchWork
 
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
 
field0 - Variable in class org.apache.hadoop.hive.serde.test.InnerStruct
 
FIELD0 - Static variable in class org.apache.hadoop.hive.serde.test.InnerStruct
 
field1 - Variable in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
FIELD1 - Static variable in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
field2 - Variable in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
FIELD2 - Static variable in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
field3 - Variable in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
FIELD3 - Static variable in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
FIELD_DELIM - Static variable in class org.apache.hadoop.hive.serde.Constants
 
FIELD_TO_DIMENSION - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
fieldid - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
fieldID - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector.MyField
 
fieldID - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
FieldList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
fieldName - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector.MyField
 
fieldName - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
fieldObjectInspector - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector.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
 
FieldRequiredness() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FIELDS - Static variable in class org.apache.hadoop.hive.metastore.api.Type
 
fields - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
fields - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
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.
FIELDSCHEMAS - Static variable in class org.apache.hadoop.hive.metastore.api.Schema
 
fieldsPresent - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
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_HEADER - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Magic cookie at start of file
FILE_INPUT_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
FILE_OUTPUT_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
fileName - Variable in class org.apache.hadoop.hive.cli.CliSessionState
-f option if any that the session has been invoked with
fileSinkDesc - Class in org.apache.hadoop.hive.ql.plan
 
fileSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.fileSinkDesc
 
fileSinkDesc(String, tableDesc, boolean, int) - Constructor for class org.apache.hadoop.hive.ql.plan.fileSinkDesc
 
fileSinkDesc(String, tableDesc, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.fileSinkDesc
 
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.RecordWriter - Interface in org.apache.hadoop.hive.ql.exec
 
FileSinkOperator.TableIdEnum - Enum in org.apache.hadoop.hive.ql.exec
 
fileSystemDeleteOnExit(FileSystem, Path) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Calls fs.deleteOnExit(path) if such a function exists.
FileUtils - Class in org.apache.hadoop.hive.common
Collection of file manipulation utilities common across Hive
FileUtils() - Constructor for class org.apache.hadoop.hive.common.FileUtils
 
FillBuff() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
filterDesc - Class in org.apache.hadoop.hive.ql.plan
 
filterDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.filterDesc
 
filterDesc(exprNodeDesc, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.filterDesc
 
FilterOperator - Class in org.apache.hadoop.hive.ql.exec
Filter operator implementation
FilterOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.FilterOperator
 
FilterOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
 
finalPath - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
find_resource_type(String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
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
findColumn(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
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.
findText(Text, Text, int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils
Finds any occurence of subtext from text in the backing buffer, for avoiding string encoding and decoding.
first() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
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
FlagArgs() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FlatFileInputFormat<T> - Class in org.apache.hadoop.hive.ql.io
An InputFormat for Plain files with Deserializer records
FlatFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
 
FlatFileInputFormat.FlatFileRecordReader<R> - Class in org.apache.hadoop.hive.ql.io
An RecordReader for plain files with Deserializer records Reads one row at a time of type R.
FlatFileInputFormat.FlatFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
FlatFileRecordReader constructor constructs the underlying stream (potentially decompressed) and creates the deserializer.
FlatFileInputFormat.RowContainer<T> - Class in org.apache.hadoop.hive.ql.io
A work-around until HADOOP-1230 is fixed.
FlatFileInputFormat.RowContainer() - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.RowContainer
 
FlatFileInputFormat.SerializationContext<S> - Interface in org.apache.hadoop.hive.ql.io
An implementation of SerializationContext is responsible for looking up the Serialization implementation for the given RecordReader.
FlatFileInputFormat.SerializationContextFromConf<S> - Class in org.apache.hadoop.hive.ql.io
An implementation of FlatFileInputFormat.SerializationContext that reads the Serialization class and specific subclass to be deserialized from the JobConf.
FlatFileInputFormat.SerializationContextFromConf() - Constructor for class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
 
FLOAT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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
 
floatWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
floatWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
flush(long) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.recman.RecordCache
Notification to flush content related to a given record.
flushAll() - Method in interface org.apache.hadoop.hive.ql.util.jdbm.recman.RecordCache
Notification to flush data all of records.
FOLLOW_aliasList_in_trfmClause5207 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_aliasList_in_trfmClause5220 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatement_in_ddlStatement679 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffix_in_alterStatement972 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixAddCol_in_alterStatementSuffix1007 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixAddPartitions_in_alterStatementSuffix1023 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixDropPartitions_in_alterStatementSuffix1015 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixProperties_in_alterStatementSuffix1031 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixRename_in_alterStatementSuffix999 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixSerdeProperties_in_alterStatementSuffix1039 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_AMPERSAND_in_precedenceAmpersandOperator7436 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_atomExpression_in_precedenceFieldExpression7073 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_BITWISEOR_in_precedenceBitwiseOrOperator7487 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_BITWISEXOR_in_precedenceBitwiseXorOperator7266 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_body_in_queryStatement3879 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_booleanValue_in_constant6883 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_caseExpression_in_atomExpression7021 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_castExpression_in_atomExpression7013 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_CharSetLiteral_in_charSetStringLiteral6921 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_CharSetName_in_charSetStringLiteral6917 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_charSetStringLiteral_in_constant6875 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_body4242 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_body4368 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_regular_body3953 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_regular_body4089 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_columnNameType3306 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnName_in_columnNameList3015 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnName_in_columnNameList3020 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_tableBuckets2096 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrder_in_columnNameOrderList3091 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrder_in_columnNameOrderList3096 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrderList_in_tableBuckets2109 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameType_in_columnNameTypeList2972 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameType_in_columnNameTypeList2977 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_alterStatementSuffixAddCol1138 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_createStatement826 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_tablePartition2040 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_trfmClause5211 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_trfmClause5224 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnRefOrder_in_orderByClause6209 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnRefOrder_in_orderByClause6219 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnRefOrder_in_sortByClause6385 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnRefOrder_in_sortByClause6395 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_aliasList5522 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_alterStatementSuffixDropPartitions1328 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_clusterByClause6277 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameList3018 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameOrderList3094 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameTypeList2975 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_distributeByClause6333 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_expressionList5475 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_function6469 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_groupByClause6120 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_hintArgs5010 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_hintList4882 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_mapType3765 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_metastoreCheck1795 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_orderByClause6217 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_partitionSpec7855 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_propertiesList2474 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_selectExpressionList5334 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_selectList4785 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_sortByClause6393 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_tableSample5849 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_constant_in_atomExpression6997 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_constant_in_partitionVal7898 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createFunctionStatement_in_ddlStatement711 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createStatement_in_ddlStatement663 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ddlStatement_in_execStatement550 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_descStatement_in_ddlStatement687 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_destination_in_insertClause4500 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_body4248 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_body4374 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_regular_body3959 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_regular_body4095 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DIVIDE_in_hintClause4830 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DIVIDE_in_hintClause4840 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_precedenceFieldExpression7089 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_tableAllColumns5387 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_tabTypeExpr1523 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropFunctionStatement_in_ddlStatement719 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropStatement_in_ddlStatement671 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EOF_in_statement459 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EOF_in_statement466 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EQUAL_in_keyValueProperty2524 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EQUAL_in_partitionVal7896 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_execStatement_in_explainStatement496 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_execStatement_in_statement464 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_explainStatement_in_statement457 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_atomExpression7048 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_caseExpression6701 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_caseExpression6710 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_caseExpression6714 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_caseExpression6725 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_castExpression6624 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_clusterByClause6269 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_clusterByClause6279 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_columnRefOrder3218 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_distributeByClause6330 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_distributeByClause6335 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_expressionList5472 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_expressionList5477 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_function6466 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_function6471 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_groupByExpression6169 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_joinSource5629 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_precedenceFieldExpression7080 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_searchCondition6070 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_selectExpression5296 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_tableSample5846 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_tableSample5853 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_whenExpression6790 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_whenExpression6794 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_whenExpression6805 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_queryStatement3869 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_regular_body3930 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_regular_body4066 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromSource_in_joinSource5612 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromSource_in_joinSource5623 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_function_in_atomExpression7005 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_functionName_in_function6438 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_listType3720 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_mapType3771 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_body4230 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_body4356 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_regular_body3941 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_regular_body4077 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByExpression_in_groupByClause6112 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByExpression_in_groupByClause6122 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintArgName_in_hintArgs5007 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintArgName_in_hintArgs5012 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintArgs_in_hintItem4927 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintClause_in_selectList4778 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintItem_in_hintList4879 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintItem_in_hintList4884 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintList_in_hintClause4836 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintName_in_hintItem4922 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_aliasList5519 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_aliasList5524 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixAddCol1120 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixAddPartitions1213 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixDropPartitions1321 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixProperties1376 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixRename1068 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixRename1076 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixSerdeProperties1426 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixSerdeProperties1472 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_columnName3064 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_columnNameOrder3134 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_columnNameType3304 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_createFunctionStatement1862 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_createStatement803 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_createStatement819 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_descStatement1654 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_dropFunctionStatement1913 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_dropStatement930 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_hintArgName5054 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_metastoreCheck1789 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_partitionVal7894 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_precedenceFieldExpression7092 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_selectItem5094 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_showStatement1743 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_subQuerySource5978 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableAllColumns5385 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableOrColumn5433 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableSource5908 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableSource5920 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tabName7801 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tabTypeExpr1520 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_createStatement798 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_insertClause_in_body4214 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_insertClause_in_regular_body3920 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_joinSource_in_fromClause5573 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_joinToken_in_joinSource5620 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_propertiesList2471 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_propertiesList2476 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ADD_in_alterStatementSuffixAddCol1125 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ADD_in_alterStatementSuffixAddPartitions1215 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_queryOperator3816 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_selectClause4658 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALTER_in_alterStatement966 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AND_in_precedenceAndOperator7674 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ARRAY_in_listType3714 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_castExpression6636 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_createFunctionStatement1864 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_selectItem5091 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat2810 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat2829 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat2848 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat2867 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_trfmClause5200 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ASC_in_columnNameOrder3139 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ASC_in_columnRefOrder3223 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BIGINT_in_primitiveType3522 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BOOLEAN_in_primitiveType3544 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BUCKET_in_tableSample5823 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BUCKETS_in_tableBuckets2121 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_clusterByClause6263 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_distributeByClause6324 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_groupByClause6106 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_orderByClause6203 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_sortByClause6379 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableBuckets2090 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableBuckets2103 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tablePartition2036 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatCollItemsIdentifier2648 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatFieldIdentifier2577 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatFieldIdentifier2586 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatLinesIdentifier2758 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatMapKeysIdentifier2704 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CASE_in_caseExpression6699 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CASE_in_whenExpression6779 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CAST_in_castExpression6605 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CLUSTER_in_clusterByClause6261 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CLUSTERED_in_tableBuckets2088 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLLECTION_in_tableRowFormatCollItemsIdentifier2642 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMNS_in_alterStatementSuffixAddCol1134 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_columnNameType3309 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_tableComment1993 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createFunctionStatement1856 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createStatement787 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATA_in_loadStatement579 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATE_in_primitiveType3610 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATETIME_in_primitiveType3634 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DELIMITED_in_serdePropertiesFormat2293 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_columnNameOrder3145 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_columnRefOrder3229 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESCRIBE_in_descStatement1613 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESCRIBE_in_descStatement1647 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DIRECTORY_in_destination4540 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DIRECTORY_in_destination4557 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISTINCT_in_function6455 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISTINCT_in_selectClause4664 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISTRIBUTE_in_distributeByClause6322 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DOUBLE_in_primitiveType3588 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_alterStatementSuffixDropPartitions1323 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropFunctionStatement1907 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropStatement926 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ELSE_in_caseExpression6723 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ELSE_in_whenExpression6803 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_END_in_caseExpression6733 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_END_in_whenExpression6813 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ESCAPED_in_tableRowFormatFieldIdentifier2584 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXISTS_in_ifNotExists750 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXPLAIN_in_explainStatement487 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_descStatement1618 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_descStatement1651 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_explainStatement492 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTERNAL_in_createStatement792 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FALSE_in_booleanValue7781 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FIELDS_in_tableRowFormatFieldIdentifier2573 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FLOAT_in_primitiveType3565 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMAT_in_serdeFormat2222 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMAT_in_serdePropertiesFormat2291 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_fromClause5571 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FULL_in_joinToken5736 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_createFunctionStatement1860 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_descStatement1649 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_dropFunctionStatement1911 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTIONS_in_showStatement1718 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GROUP_in_groupByClause6104 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IF_in_ifNotExists746 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPATH_in_loadStatement588 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTFORMAT_in_tableFileFormat2869 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INSERT_in_insertClause4496 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INT_in_primitiveType3497 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INTO_in_loadStatement603 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INTO_in_tableBuckets2115 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IS_in_precedenceUnarySuffixExpression7216 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ITEMS_in_tableRowFormatCollItemsIdentifier2644 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken5667 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken5703 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken5722 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken5740 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_KEYS_in_tableRowFormatMapKeysIdentifier2700 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LEFT_in_joinToken5699 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_createStatement815 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIMIT_in_limitClause4610 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LINES_in_tableRowFormatLinesIdentifier2754 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOAD_in_loadStatement577 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCAL_in_destination4538 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCAL_in_loadStatement584 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_partitionLocation1281 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_tableLocation2930 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_mapType3757 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_tableRowFormatMapKeysIdentifier2698 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_trfmClause5159 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAPJOIN_in_hintName4972 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MSCK_in_metastoreCheck1782 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_ifNotExists748 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_nullCondition7159 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_precedenceNotOperator7625 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NULL_in_atomExpression6985 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NULL_in_nullCondition7145 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NULL_in_nullCondition7161 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OF_in_tableSample5833 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_joinSource5626 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_tableSample5842 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OR_in_precedenceOrOperator7725 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ORDER_in_orderByClause6201 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUT_in_tableSample5831 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTER_in_joinToken5701 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTER_in_joinToken5720 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTER_in_joinToken5738 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTPUTFORMAT_in_tableFileFormat2875 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OVERWRITE_in_insertClause4498 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OVERWRITE_in_loadStatement599 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITION_in_partitionSpec7843 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITIONED_in_tablePartition2034 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITIONS_in_showStatement1741 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PROPERTIES_in_alterStatementSuffixProperties1380 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RCFILE_in_tableFileFormat2850 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REDUCE_in_trfmClause5174 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RENAME_in_alterStatementSuffixRename1070 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REPLACE_in_alterStatementSuffixAddCol1131 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RIGHT_in_joinToken5718 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROW_in_serdeFormat2220 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROW_in_serdePropertiesFormat2289 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SELECT_in_selectClause4655 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SELECT_in_trfmClause5141 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SEQUENCEFILE_in_tableFileFormat2812 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDE_in_alterStatementSuffixSerdeProperties1430 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDE_in_serdeFormat2224 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_alterStatementSuffixSerdeProperties1439 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_alterStatementSuffixSerdeProperties1476 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_serdeFormat2233 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixProperties1378 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixSerdeProperties1428 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixSerdeProperties1474 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement1693 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement1716 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement1739 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SMALLINT_in_primitiveType3477 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SORT_in_sortByClause6377 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SORTED_in_tableBuckets2101 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat2808 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat2827 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat2846 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat2865 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STRING_in_primitiveType3673 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_alterStatement969 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_createStatement796 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_destination4574 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_dropStatement928 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_loadStatement605 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_metastoreCheck1785 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLES_in_showStatement1695 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLESAMPLE_in_tableSample5819 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_createFunctionStatement1858 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_dropFunctionStatement1909 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatCollItemsIdentifier2646 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatFieldIdentifier2575 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatLinesIdentifier2756 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatMapKeysIdentifier2702 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEXTFILE_in_tableFileFormat2831 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_THEN_in_caseExpression6712 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_THEN_in_whenExpression6792 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TIMESTAMP_in_primitiveType3654 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TINYINT_in_primitiveType3456 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_alterStatementSuffixRename1072 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TRANSFORM_in_trfmClause5143 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TRUE_in_booleanValue7776 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNION_in_queryOperator3814 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_USING_in_trfmClause5189 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WHEN_in_caseExpression6708 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WHEN_in_whenExpression6788 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WHERE_in_whereClause6029 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_alterStatementSuffixSerdeProperties1437 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_serdeFormat2231 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_listType3716 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_mapType3759 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_body4260 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_body4386 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_regular_body3971 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_regular_body4107 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_listType_in_type3426 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_loadStatement_in_execStatement542 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_alterStatementSuffixAddCol1136 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_atomExpression7045 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_castExpression6611 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_createStatement824 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_function6444 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_hintItem4925 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_partitionSpec7850 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_subQuerySource5972 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableBuckets2092 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableBuckets2105 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tablePartition2038 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableProperties2426 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableSample5821 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_trfmClause5145 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_trfmClause5204 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LSQUARE_in_precedenceFieldExpression7077 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_mapType_in_type3434 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_metastoreCheck_in_ddlStatement703 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_nullCondition_in_precedenceUnarySuffixExpression7218 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_constant6859 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_limitClause4614 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_tableBuckets2119 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_tableSample5828 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_tableSample5838 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_body4236 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_body4362 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_regular_body3947 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_regular_body4083 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionLocation_in_alterStatementSuffixAddPartitions1219 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionLocation_in_alterStatementSuffixAddPartitions1225 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixAddPartitions1217 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixAddPartitions1223 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixDropPartitions1325 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixDropPartitions1330 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_metastoreCheck1791 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_metastoreCheck1797 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_partTypeExpr1574 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_tabName7803 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionVal_in_partitionSpec7852 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionVal_in_partitionSpec7858 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partTypeExpr_in_descStatement1625 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_PLUS_in_hintClause4834 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAmpersandExpression_in_precedenceBitwiseOrExpression7508 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAmpersandExpression_in_precedenceBitwiseOrExpression7514 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAmpersandOperator_in_precedenceAmpersandExpression7460 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAndExpression_in_precedenceOrExpression7746 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAndExpression_in_precedenceOrExpression7752 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAndOperator_in_precedenceAndExpression7698 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression7595 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression7601 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseOrOperator_in_precedenceBitwiseOrExpression7511 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseXorExpression_in_precedenceStarExpression7351 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseXorExpression_in_precedenceStarExpression7357 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseXorOperator_in_precedenceBitwiseXorExpression7290 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceEqualExpression_in_precedenceNotExpression7652 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceEqualOperator_in_precedenceEqualExpression7598 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceFieldExpression_in_precedenceUnaryPrefixExpression7194 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceNotExpression_in_precedenceAndExpression7695 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceNotExpression_in_precedenceAndExpression7701 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceNotOperator_in_precedenceNotExpression7647 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceOrExpression_in_expression6964 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceOrOperator_in_precedenceOrExpression7749 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedencePlusExpression_in_precedenceAmpersandExpression7457 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedencePlusExpression_in_precedenceAmpersandExpression7463 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedencePlusOperator_in_precedencePlusExpression7409 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceStarExpression_in_precedencePlusExpression7406 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceStarExpression_in_precedencePlusExpression7412 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceStarOperator_in_precedenceStarExpression7354 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceUnaryOperator_in_precedenceUnaryPrefixExpression7189 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceUnaryPrefixExpression_in_precedenceUnarySuffixExpression7211 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceUnarySuffixExpression_in_precedenceBitwiseXorExpression7287 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceUnarySuffixExpression_in_precedenceBitwiseXorExpression7293 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_primitiveType_in_castExpression6648 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_primitiveType_in_mapType3763 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_primitiveType_in_type3418 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_propertiesList_in_tableProperties2428 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryOperator_in_queryStatementExpression3843 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatement_in_queryStatementExpression3840 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatement_in_queryStatementExpression3846 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatementExpression_in_execStatement534 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatementExpression_in_subQuerySource5974 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_regular_body_in_queryStatement3901 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_alterStatementSuffixAddCol1140 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_atomExpression7050 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_castExpression6654 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_createStatement828 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_function6481 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_hintItem4929 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_partitionSpec7863 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_subQuerySource5976 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableBuckets2098 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableBuckets2111 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tablePartition2042 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableProperties2430 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableSample5859 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_trfmClause5149 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_trfmClause5214 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RSQUARE_in_precedenceFieldExpression7082 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_searchCondition_in_whereClause6031 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_body4219 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_body4345 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_regular_body3925 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_regular_body4061 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpression_in_selectExpressionList5331 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpression_in_selectExpressionList5336 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpression_in_selectItem5087 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpressionList_in_trfmClause5147 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpressionList_in_trfmClause5164 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpressionList_in_trfmClause5176 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectItem_in_selectList4781 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectItem_in_selectList4788 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectList_in_selectClause4672 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_serde_in_trfmClause5186 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_serde_in_trfmClause5230 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_serdeFormat_in_serde2169 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_serdeFormat_in_tableRowFormat2381 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_serdePropertiesFormat_in_serde2185 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_serdePropertiesFormat_in_tableRowFormat2361 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_set_in_functionName0 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_set_in_precedenceEqualOperator0 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_set_in_precedencePlusOperator0 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_set_in_precedenceStarOperator0 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_set_in_precedenceUnaryOperator0 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_set_in_showStmtIdentifier0 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_set_in_tabTypeExpr1526 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStatement_in_ddlStatement695 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement1697 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement1720 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_body4254 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_body4380 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_regular_body3965 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_regular_body4101 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_hintClause4832 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_hintClause4838 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_tableAllColumns5371 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_tableAllColumns5389 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixSerdeProperties1434 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_columnNameType3313 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_constant6867 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_createFunctionStatement1866 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_destination4542 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_destination4559 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_keyValueProperty2522 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_keyValueProperty2528 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_loadStatement593 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_partitionLocation1285 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_serdeFormat2228 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableComment1997 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat2873 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat2879 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableLocation2934 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatCollItemsIdentifier2652 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatFieldIdentifier2581 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatFieldIdentifier2590 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatLinesIdentifier2762 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatMapKeysIdentifier2708 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_trfmClause5191 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_subQuerySource_in_fromSource5783 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableAllColumns_in_selectExpression5300 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableBuckets_in_createStatement838 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableComment_in_createStatement832 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableFileFormat_in_createStatement844 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableLocation_in_createStatement849 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrColumn_in_atomExpression7037 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePartition_in_createStatement835 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixProperties1382 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixSerdeProperties1441 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixSerdeProperties1478 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_serdeFormat2237 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormat_in_createStatement841 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatCollItemsIdentifier_in_serdePropertiesFormat2298 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatFieldIdentifier_in_serdePropertiesFormat2295 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatLinesIdentifier_in_serdePropertiesFormat2304 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatMapKeysIdentifier_in_serdePropertiesFormat2301 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableSample_in_tableSource5913 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableSource_in_fromSource5779 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tabName_in_destination4576 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tabName_in_loadStatement610 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tabTypeExpr_in_partTypeExpr1572 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_trfmClause_in_selectClause4734 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_colType3401 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_listType3718 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_mapType3769 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whenExpression_in_atomExpression7029 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_body4224 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_body4350 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_regular_body3935 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_regular_body4071 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
forward(ArrayList<Object>, GenericUDAFEvaluator.AggregationBuffer[]) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
Forward a record of keys and aggregation results.
forward(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
forwardDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
FREE_PAGE - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Magics for blocks in certain lists.
FREELOGIDS_PAGE - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
 
FREEPHYSIDS_PAGE - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
 
fromClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fromSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fs - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
FULL_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.joinDesc
 
func(Operator) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapper.reportStats
 
func(Operator<? extends Serializable>) - Method in interface org.apache.hadoop.hive.ql.exec.Operator.OperatorFunc
 
function() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Function() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FunctionInfo - Class in org.apache.hadoop.hive.ql.exec
 
FunctionInfo(String, Class<? extends UDF>, Class<? extends GenericUDF>) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, Class<? extends UDF>, Class<? extends GenericUDF>) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(String, GenericUDAFResolver) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, GenericUDAFResolver) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo.OperatorType - Enum in org.apache.hadoop.hive.ql.exec
 
functionName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FunctionRegistry - Class in org.apache.hadoop.hive.ql.exec
 
FunctionRegistry() - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
FunctionSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
 
FunctionSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.FunctionSemanticAnalyzer
 
FunctionTask - Class in org.apache.hadoop.hive.ql.exec
 
FunctionTask() - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionTask
 
FunctionType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FunctionWork - Class in org.apache.hadoop.hive.ql.plan
 
FunctionWork(createFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
 
FunctionWork(dropFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
 

G

genColLists(HashMap<Operator<? extends Serializable>, OpParseContext>) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
genColLists(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
Creates the list of internal column names(these names are used in the RowResolver and are different from the external column names) that are needed in the subtree.
generateCmdLine(HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.ExecDriver
Given a Hive Configuration object - generate a command line fragment for passing such configuration information to ExecDriver
generateParseException() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Generate ParseException.
GenericUDAFAverage - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFAverage() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage
 
GenericUDAFAverage.GenericUDAFAverageEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFAverage.GenericUDAFAverageEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluator
 
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
 
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
 
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
 
GenericUDAFCount.GenericUDAFCountEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
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.AggregationBuffer - Interface in org.apache.hadoop.hive.ql.udf.generic
The interface for a class that is used to store the aggregation result during the process of aggregation.
GenericUDAFEvaluator.Mode - Enum in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFResolver - Interface in org.apache.hadoop.hive.ql.udf.generic
A Generic User-defined aggregation function (GenericUDAF) for the use with Hive.
GenericUDAFStd - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the standard deviation by extending GenericUDAFVariance and overriding the terminate() method of the evaluator.
GenericUDAFStd() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStd
 
GenericUDAFStd.GenericUDAFStdEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the standard deviation by extending GenericUDAFVarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFStd.GenericUDAFStdEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStd.GenericUDAFStdEvaluator
 
GenericUDAFStdSample - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample standard deviation by extending GenericUDAFVariance and overriding the terminate() method of the evaluator.
GenericUDAFStdSample() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample
 
GenericUDAFStdSample.GenericUDAFStdSampleEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample standard deviation by extending GenericUDAFVarianceEvaluator and overriding the terminate() method of the evaluator
GenericUDAFStdSample.GenericUDAFStdSampleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample.GenericUDAFStdSampleEvaluator
 
GenericUDAFSum - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFSum() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum
 
GenericUDAFSum.GenericUDAFSumDouble - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFSum.GenericUDAFSumDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
GenericUDAFSum.GenericUDAFSumLong - Class in org.apache.hadoop.hive.ql.udf.generic
 
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 following modification of the formula from The Art of Computer Programming, vol.
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.DeferredObject - Interface in org.apache.hadoop.hive.ql.udf.generic
A Defered Object allows us to do lazy-evaluation and short-circuiting.
GenericUDFCase - 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".
GenericUDFCase() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCase
 
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
 
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
 
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
 
GenericUDFIndex - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFIndex() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
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
 
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
 
GenericUDFOPNotNull - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPNotNull() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
GenericUDFOPNull - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFOPNull() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
GenericUDFSize - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFSize() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
GenericUDFSplit - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFSplit() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
GenericUDFUtils - Class in org.apache.hadoop.hive.ql.udf.generic
Util functions for GenericUDF classes.
GenericUDFUtils() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils
 
GenericUDFUtils.PrimitiveConversionHelper - Class in org.apache.hadoop.hive.ql.udf.generic
Convert primitive parameters between Java and Writable when needed.
GenericUDFUtils.PrimitiveConversionHelper(Method, ObjectInspector[]) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.PrimitiveConversionHelper
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
 
GenericUDFWhen - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for SQL construct "CASE a WHEN b THEN c [ELSE f] END".
GenericUDFWhen() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFWhen
 
genExprNodeDesc(ASTNode, RowResolver) - Static method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Generates and expression node descriptor for the expression passed in the arguments.
GenMapRedUtils - Class in org.apache.hadoop.hive.ql.optimizer
General utility common functions for the Processor to convert operator into map-reduce tasks
GenMapRedUtils() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
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 Serializable>, Task<? extends Serializable>>, List<Operator<? extends Serializable>>, ParseContext, List<Task<? extends Serializable>>, List<Task<? extends Serializable>>, LinkedHashMap<Operator<? extends Serializable>, 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>, Operator<? extends Serializable>, String) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
GenMRProcContext.GenMRMapJoinCtx - Class in org.apache.hadoop.hive.ql.optimizer
 
GenMRProcContext.GenMRMapJoinCtx() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
GenMRProcContext.GenMRMapJoinCtx(String, tableDesc, Operator<? extends Serializable>, MapJoinOperator) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
GenMRProcContext.GenMRUnionCtx - Class in org.apache.hadoop.hive.ql.optimizer
 
GenMRProcContext.GenMRUnionCtx() - 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
 
GenMRRedSink4 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - map join followed by reduce sink
GenMRRedSink4() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRRedSink4
 
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 - any operator tree followed by union
GenMRUnion1() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRUnion1
 
genPlan(QB) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
genPruner(String, exprNodeDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
Generates the partition pruner for the expression tree
get() - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get(exprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorFactory
 
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 Serializable>...) - 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(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(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(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(String) - 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 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(Object) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.CachePolicy
Obtain the object stored under the key specified.
get(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Obtain an object in the cache
get(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Gets the object cached under the specified key.
get(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.htree.HTree
Returns the value which is associated with the given key.
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.ByteWritable
 
get() - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
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.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 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_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_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_databases() - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_databases() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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_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_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_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_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_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_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) - 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) - 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
 
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
getAddPartitionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAggregationExprsForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getAggregators() - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
getAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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.plan.tableScanDesc
 
getAlias(exprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Returns the alias of the specified expr
getAliasToFetchWork() - Method in class org.apache.hadoop.hive.ql.plan.mapredLocalWork
 
getAliasToPartnInfo() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
getAliasToPruner() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getAliasToSamplePruner() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getAliasToTable() - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getAliasToWork() - Method in class org.apache.hadoop.hive.ql.plan.mapredLocalWork
 
getAliasToWork() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
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.
getAllProperties() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getAllStructFieldNames() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
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.UnionStructObjectInspector
 
getAllStructFieldTypeInfos() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getAllTables() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getAlterTableTypeString() - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
getAlterTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAndIncrementId() - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
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, 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, HiveConf, Task<? extends Serializable>...) - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
getArgumentId() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentTypeException
 
getArray(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getArray(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getArray(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getArray(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getAsciiStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getAsciiStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getAstStringTree() - Method in class org.apache.hadoop.hive.ql.plan.explainWork
 
getAttributes(String, String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getAuth() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getAutoCommit() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getAuxJars() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getBaseSrc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
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.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getBigDecimal(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBigDecimal(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBigDecimal(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBigDecimal(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBigDecimal(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBigDecimal(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBigDecimal(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBinaryStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBinaryStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBlob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBlob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBlob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBlob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBoolean(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBoolean(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBoolean(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBoolean(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
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.
getBoolExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get BoolExprProcessor.
getBoolVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getBoolVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
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.createTableDesc
 
getBucketColsIterator() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getBucketColsSize() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getBucketCount() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
The number of buckets is a property of the partition.
getBucketingDimensionId() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getBucketNum(Path) - Static method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getBucketPath(int) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
mapping from bucket number to bucket path
getBufferSize() - Method in class org.apache.hadoop.hive.ql.plan.collectDesc
 
getByte(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getByte(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getByte(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getByte(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getByte(String, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
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.
getBytes(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBytes(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBytes(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBytes(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getBytesCopy() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Returns a copy of the underlying bytes referenced by this instance.
getByteValue(String, String) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
getCachePolicy() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Get the underlying cache policy
getCatalog() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getCatalogName(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getCatalogs() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getCatalogSeparator() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getCatalogTerm() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
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.LazySimpleStructObjectInspector
 
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.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.
getChangedProperties() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getCharacterStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getCharacterStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getCharacterStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getCharacterStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getCheckFileFormat() - Method in class org.apache.hadoop.hive.ql.plan.moveWork
 
getChildExprs() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
getChildExprs() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
getChildOperators() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getChildren() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Implements the getChildren function for the Node Interface.
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.exprNodeDesc
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
getChildren() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
getChildTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
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.ql.plan.createFunctionDesc
 
getClauseNames() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getClauseNamesForDest() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getClientInfo() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getClientInfo(String) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getClientInfoProperties() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getClob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getClob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getClob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getClob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
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() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Return the status information about the Map-Reduce cluster
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.session.SessionState
 
getCol() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
getCol() - Method in class org.apache.hadoop.hive.metastore.model.MOrder
 
getCol() - Method in class org.apache.hadoop.hive.ql.plan.extractDesc
 
getColList() - Method in class org.apache.hadoop.hive.ql.plan.selectDesc
 
getCollItemDelim() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getColNames() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getColNamesIterator() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getColNamesSize() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getCols() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getCols() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
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.exprNodeDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
getCols() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
getColsFromSelectExpr(SelectOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
Creates the list of internal column names from select expressions in a select operator.
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
 
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.  
getColumnarStructObjectInspector(List<String>, List<ObjectInspector>, Text) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getColumnClassName(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnCount() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnDisplaySize(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnExprMap() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Returns a map of output column name to input expression map Note that currently it returns only key columns for ReduceSink and GroupBy operators
getColumnExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get ColumnExprProcessor.
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.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnName(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnNames() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getColumnNamesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to columnNames.
getColumnNumber(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
Returns the number of columns set in the conf for writers
getColumnPrivileges(String, String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
 
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
getColumns(String, String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
getColumnType(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnTypeName(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnTypes() - Method in class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
getColumnTypes() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getColumnTypesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to columnTypes.
getCommand() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
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.createTableDesc
 
getComments() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
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.
getCompressed() - Method in class org.apache.hadoop.hive.ql.plan.fileSinkDesc
 
getCompressionCodec() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
Returns the compression codec of data in this file.
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.
getConcurrency() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
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.metastore.HiveAlterHandler
 
getConf() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getConf() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
 
getConf() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getConf() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getConfirmedPartns() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
get confirmed partitions
getConnection() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getConnection() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getConnection() - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
getConnection(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
getConnection() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getConnection() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getConsole() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
initialize or retrieve console object for SessionState
getContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getConvertedNode(Node) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
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.
getCount() - Method in class org.apache.hadoop.hive.serde2.ByteStream.Input
 
getCount() - Method in class org.apache.hadoop.hive.serde2.ByteStream.Output
 
getCpuProfile(int) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getCreateFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
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.Partition
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getCrossReference(String, String, String, String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getCurrAliasId() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
getCurrAliasId() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrentMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
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.
getCurrMapJoinOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
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.GenMapRedCtx
 
getCurrTopOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrUnionOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurSize() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator.IntermediateObject
 
getCursorName() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getData() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
 
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.serde2.binarysortable.InputByteBuffer
Returns the underlying byte array.
getData() - Method in class org.apache.hadoop.hive.serde2.binarysortable.OutputByteBuffer
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
 
getDatabase(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
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
 
getDatabaseMajorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseMinorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseProductName() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseProductVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDatabases() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getDatabases() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDatabases() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getDataLocation() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getDataLocation() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDate(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getDate(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getDate(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getDate(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getDate(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getDate(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getDate(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getDate(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getDb() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
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.append_partition_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.get_fields_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_names_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_schema_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.drop_table_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
getDbName() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getDDLFromFieldSchema(String, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to Thrift DDL.
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 class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getDefaultDatabasePath(String) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
 
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get DefaultExprProcessor.
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
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.ppr.OpProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
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.
getDefaultTablePath(String, String) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
getDefaultTransactionIsolation() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDeniedPartns() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
get denied partitions
getDenominator() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the denominator
getDesc() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
getDescFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getDescription() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
getDescription() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getDescTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDeserializer(Configuration, Properties) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
getDeserializer Get the Deserializer for a table given its name and properties.
getDeserializer(Configuration, Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
getDeserializer Get the Deserializer for a table.
getDeserializer() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDeserializer() - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
Return a deserializer object corresponding to the tableDesc
getDeserializerClass() - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
getDestFileForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getDestForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestLimit(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestPartitionForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
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
 
getDestToClusterBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToDistributeBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToOrderBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToSortBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToWhereExpr() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestTypeForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getDimensionId() - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
getDimensionType() - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
getDir() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
getDirName() - Method in class org.apache.hadoop.hive.ql.plan.fileSinkDesc
 
getDispatchedList() - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
getDisplayName() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
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.GenericUDFCase
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFElt
 
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.GenericUDFIndex
 
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.GenericUDFLocate
 
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.GenericUDFSize
 
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.GenericUDFWhen
 
getDistinct() - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
getDistinctFuncExprForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDistributeByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Get the Distribute By AST for the clause.
getDnsPath(Path) - 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.
getDone() - Static method in class org.apache.hadoop.hive.ql.exec.ExecMapper
 
getDone() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getDouble(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getDouble(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getDouble(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getDouble(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getDouble(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the double value out of a primitive object.
getDriverMajorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDriverMinorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDriverName() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDriverVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDropFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
getDropTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getElementType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
getElementType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
getEndColumn() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getEndLine() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getError() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getErrorFile() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Currently unused
getErrorMessage(RecognitionException, String[]) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
getErrorMessage(RecognitionException, String[]) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveParserX
 
getErrors() - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
getErrors() - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveParserX
 
getErrStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getEscapeChar() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
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.primitive.LazyStringObjectInspector
 
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(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.GenericUDAFCount
 
getEvaluator(TypeInfo[]) - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFResolver
Get the evaluator for the parameter types.
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
 
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.
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.getSchema_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
getException() - Method in exception org.apache.hadoop.hive.ql.util.jdbm.helper.WrappedRuntimeException
Returns the exception wrapped by this runtime exception.
getExplain() - Method in class org.apache.hadoop.hive.ql.Context
Find out whether the current query is an explain query
getExportedKeys(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getExpressions() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
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.joinDesc
 
getExprsStringMap() - Method in class org.apache.hadoop.hive.ql.plan.joinDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeConstantDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeNullDesc
 
getExtended() - Method in class org.apache.hadoop.hive.ql.plan.explainWork
 
getExternalTmpFileURI(URI) - Method in class org.apache.hadoop.hive.ql.Context
Get a path to store tmp data destined for external URI
getExtraNameCharacters() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getFetchDirection() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getFetchDirection() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getFetchDirection() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getFetchDirection() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getFetchSize() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getFetchSize() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getFetchSize() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getFetchSize() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getFetchTask() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getFetchTaskInit() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getField(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getField(int, Text) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStruct
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(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct
Get one field out of the struct.
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
 
getFieldDelim() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getFieldEscape() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getFieldID() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector.MyField
 
getFieldID() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
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 class org.apache.hadoop.hive.ql.plan.explosionDesc
 
getFieldName() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
getFieldName() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector.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
 
getFieldNames(StructObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get the list of field names as csv from a StructObjectInspector.
getFieldObjectInspector() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector.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.ppr.ExprProcFactory
 
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.metadata.Table
 
getFieldsAsList(Text) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStruct
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.
getFieldSchemaFromTypeInfo(String, TypeInfo) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert TypeInfo to FieldSchema.
getFieldSchemas() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getFieldSchemasFromColumnInfo(Vector<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.
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
 
getFieldTypes(StructObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get the list of field type as csv from a StructObjectInspector.
getFieldValue(int) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getFieldValue(int) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
getFieldValue(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
getFieldValue(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
getFieldValue(int) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
getFieldValue(int) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getFieldValue(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
getFieldValue(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getFieldValue(int) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
getFieldValue(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
getFileExtension(JobConf, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Based on compression option and configured output codec - get extension for output file.
getFileSystem() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.MiniDFSShim
 
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.ppr.OpProcFactory
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getFilters() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
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.
getFloat(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getFloat(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getFloat(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getFloat(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getFloat(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the float value out of a primitive object.
getFloatVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getFloatVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getFromPath() - Method in class org.apache.hadoop.hive.ql.plan.copyWork
 
getFs(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
Helper function to convert IOException to MetaException
getFullDDLFromFieldSchema(String, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to Thrift DDL + column names and column types
getFuncExprNodeDesc(String, exprNodeDesc...) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
Get the exprNodeDesc
getFuncExprNodeDesc(String, List<exprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
This function create an ExprNodeDesc for a UDF function given the children (arguments).
getFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
 
getFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
getFunctionColumns(String, String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getFunctionInfo(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getFunctionName() - Method in class org.apache.hadoop.hive.ql.plan.createFunctionDesc
 
getFunctionName() - Method in class org.apache.hadoop.hive.ql.plan.dropFunctionDesc
 
getFunctionNames() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns a set of registered function names.
getFunctionNames(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns a set of registered function names.
getFunctions(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getFunctionText(ASTNode, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
getGeneratedKeys() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getGeneratedKeys() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getGeneratedKeys() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
 
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
getGenericUDAFEvaluator(String, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Get the GenericUDAF evaluator for the name and argumentClasses.
getGenericUDAFEvaluator() - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
getGenericUDAFEvaluatorClass() - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
getGenericUDAFName() - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
getGenericUDAFResolver() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
getGenericUDAFResolver(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getGenericUDFClass() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
getGenericUDFClass() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
getGenericUDFClassForIndex() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
A shortcut to get the index GenericUDFClass.
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getGroupByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerGroupByProc class.
getGroupKeyNotReductionKey() - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
getGroups() - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
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.
getHasNonPartCols() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcCtx
 
getHasNonPartCols() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpWalkerCtx
 
getHasNonPartCols() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
Gets the value of the hasNonPartCols flag
getHints() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getHistFileName() - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
 
getHistoryViewer() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
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
 
getHiveHistory() - Method in class org.apache.hadoop.hive.ql.session.SessionState
get hiveHitsory object which does structured logging
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 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.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.RCFileOutputFormat
create the final out file,
getHoldability() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getHoldability() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getId() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getId() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getIdToTableNameMap() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getIdToTableNameMap() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.createTableLikeDesc
 
GetImage() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getImportedKeys(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getIndexName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getIndexType() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getInput() - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
getInputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
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.plan.createTableDesc
 
getInputFormatChecker(Class<?>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
get an InputFormatChecker for a file format.
getInputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getInputPruning() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the flag that indicates whether input pruning is possible
getInputRR() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
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 class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getInputSplit() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getInputTableList() - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
getInstance(List<String>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.MetadataListStructObjectInspector
 
getInt(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getInt(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getInt(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getInt(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getInt(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the integer value out of a primitive object.
getIntermediateFileTableDesc(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for intermediate files.
getInternalName() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
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
 
getIsDfsDir() - Method in class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
getIsExprResolver() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getIsList() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
getIsParititonCol() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
getIsPartitionCol() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
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
 
getItems() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
getItemSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getJar() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
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().
getJDBCMajorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getJDBCMinorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
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.
getJobInfoMap() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getJobTrackerURL(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getJoinCond() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getJoinCondString() - Method in class org.apache.hadoop.hive.ql.plan.joinCond
 
getJoinContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getJoinExpr() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getJoinOutputObjectInspector(Byte[], Map<Byte, List<ObjectInspector>>, T) - Static method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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.ppd.OpProcFactory
 
getJoinPrunedColLists() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getJoinSrc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getJoinStreamDesc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getJoinType() - Method in class org.apache.hadoop.hive.ql.parse.joinCond
 
getJSONString(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
getKey() - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Tuple
Get the key.
getKeyClass() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getKeyCols() - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
getKeyDesc() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
getKeys() - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
getKeys() - Method in class org.apache.hadoop.hive.ql.plan.mapJoinDesc
 
getKeySerializeInfo() - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
getKeyTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.mapJoinDesc
 
getKeyType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
getKeyValueSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getLastColumnTakesRest() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
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
 
getLazyObjectInspector(PrimitiveObjectInspector.PrimitiveCategory, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
getLazySimpleListObjectInspector(ObjectInspector, byte, Text, boolean, byte) - 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
 
getLazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, byte, Text, boolean, boolean, byte) - 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
 
getLeft() - Method in class org.apache.hadoop.hive.ql.parse.joinCond
 
getLeft() - Method in class org.apache.hadoop.hive.ql.plan.joinCond
 
getLeftAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
returns left alias if any - this is used for merging later on
getLeftAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getLength() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
getLength() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
 
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.RCFile.Writer
 
getLength() - Method in class org.apache.hadoop.hive.serde2.binarysortable.OutputByteBuffer
Returns the current length.
getLength() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 
getLikeTableName() - Method in class org.apache.hadoop.hive.ql.plan.createTableLikeDesc
 
getLimit() - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
getLimit() - Method in class org.apache.hadoop.hive.ql.plan.limitDesc
 
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.  
getLineageInfo(String) - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
parses given query and gets the lineage info.
getLineDelim() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getLint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintStringIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintStringSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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
 
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.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
 
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
 
getListTasks() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getListTasks() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
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
 
getLoadFileWork() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getLoadFileWork() - Method in class org.apache.hadoop.hive.ql.plan.moveWork
 
getLoadTableWork() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getLoadTableWork() - Method in class org.apache.hadoop.hive.ql.plan.moveWork
 
getLocalTmpFileURI() - Method in class org.apache.hadoop.hive.ql.Context
Get a tmp path on local host to store intermediate data
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.ql.hooks.ReadEntity
Get the location of the entity.
getLocation() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Get the location of the entity.
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.createTableLikeDesc
 
getLocations() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getLogDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getLogFile() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getLoginTimeout() - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
getLogWriter() - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
getLong(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getLong(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getLong(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getLong(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getLong(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the long value out of a primitive object.
getLongVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getLongVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLStringIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLStringSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getMajorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
Returns the major version of this driver.
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
 
getMapAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getMapCurrCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getMapJoinCtx(MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getMapJoinDefault() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getMapJoinFS() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getMapJoinKeyTableDesc(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for Map-side join key.
getMapJoinMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getMapJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
The Factory method to get ColumnMapJoinProc class.
getMapJoinValueTableDesc(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for Map-side join key.
getMapKeyDelim() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
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
 
getMapKeyTypeInfo() - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
getMapLocalWork() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
getMapMetadata() - Static method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
getMapOnlySubq(int) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getMapProp() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
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() - 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
 
getMapSeparator() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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.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.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
 
getMapValueTypeInfo() - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
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_partitions_args
 
getMaxBinaryLiteralLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxCatalogNameLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxCharLiteralLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnNameLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInGroupBy() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInIndex() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInOrderBy() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInSelect() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxColumnsInTable() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxConnections() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxCursorNameLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxFieldSize() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getMaxFieldSize() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getMaxFieldSize() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getMaxIndexLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getMaxProcedureNameLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getMaxRows() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getMaxRows() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getMaxRows() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
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
getMaxRowSize() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxSchemaNameLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxStatementLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxStatements() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxTableNameLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxTablesInSelect() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMaxUserNameLength() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
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.MetaException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
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
 
getMetaData() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getMetaData() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getMetaData() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getMetaData() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getMetaData() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getMetaData(QB) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getMetadataTag() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
getMetadataTag() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
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(ArrayList<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.
getMethodName() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
getMiniDfs(Configuration, int, boolean, String[]) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Returns a shim to wrap MiniDFSCluster.
getMinorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
Returns the minor version of this driver.
getMode() - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
getMode() - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
getModeString() - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
getMoreResults() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getMoreResults(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getMoreResults() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getMoreResults(int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getMoreResults() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getMoreResults(int) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getMRTmpFileURI() - Method in class org.apache.hadoop.hive.ql.Context
Get a path to store map-reduce intermediate data in
getMsckDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getMsg(ASTNode) - Method in enum org.apache.hadoop.hive.ql.parse.ErrorMsg
 
getMsg(String) - Method in enum org.apache.hadoop.hive.ql.parse.ErrorMsg
 
getMsg() - Method in enum org.apache.hadoop.hive.ql.parse.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
 
getMvTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getMyint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.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.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.create_database_args
 
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.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.MSerDeInfo
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.MType
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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.GroupByOperator
 
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.Operator
Implements the getName function for the Node Interface.
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.TableScanOperator
The operator name for this operator type.
getName() - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
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.RuleRegExp
 
getName() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getName() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
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.plan.descFunctionDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
getNamedObject(String) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Obtain the record id of a named object.
getNamedObject(String) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Obtain the record id of a named object.
getNamedObject(String) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Obtain the record id of a named object.
getNameMessage(Exception) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getNCharacterStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNCharacterStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNCharacterStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getNCharacterStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getNClob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNClob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNClob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getNClob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getNeededColumnIDs() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getNeedsEscape() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getNeedsTagging() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
getNestedException() - Method in exception org.apache.hadoop.hive.ql.util.jdbm.helper.CacheEvictionException
 
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.alter_partition_args
 
getNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
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.GenericUDAFSum.GenericUDAFSumDouble
 
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
 
getNewCols() - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
getNewColsString() - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
getNewName() - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
getNext(Tuple) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.TupleBrowser
Get the next tuple.
getNextRow() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Get the next row.
getNextSize(int) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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.
getNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.plan.joinDesc
 
getNoUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getNString(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNString(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNString(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getNString(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getNullExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get NullExprProcessor.
getNullSequence() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
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
 
getNullString() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
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.metadata.Table
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getNumerator() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the numerator
getNumericFunctions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getNumExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get NumExprProcessor.
getNumGbys() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumInputs() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getNumInputs() - Method in class org.apache.hadoop.hive.ql.plan.unionDesc
 
getNumJoins() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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.mapredWork
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.service.ThriftHive.fetchN_args
 
getNumSelDi() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumSels() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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.alter_partition_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.append_partition_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_table_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.drop_partition_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.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_fields_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_partitions_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_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_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.alter_partition_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.append_partition_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_table_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.drop_database_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_type_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_partition_names_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_schema_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_type_all_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_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.append_partition_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_type_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.get_fields_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getObj() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
getObj() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
getObject(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getObject(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getObject(int, Map<String, Class<?>>) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getObject(String, Map<String, Class<?>>) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getObject(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getObject(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getObject(int, Map<String, Class<?>>) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getObject(String, Map<String, Class<?>>) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
getObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
If the LazyObject is a primitive Object, then deserialize it and return the actual primitive Object.
getObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
Returns the primitive object represented by this LazyObject.
getObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
getObject() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
getObject() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryObject
If the LazyBinaryObject is a primitive Object, then deserialize it and return the actual primitive Object.
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
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
Returns the ObjectInspector for the row.
getObjectInspector() - Method in interface org.apache.hadoop.hive.serde2.Deserializer
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.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.thrift.ThriftDeserializer
 
getObjectInspector() - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
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
 
getObjectInspectorsFromEvaluators(Map<Byte, List<ExprNodeEvaluator>>, ObjectInspector[]) - Static method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getObjs() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator.IntermediateObject
 
getOldMapJoin() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
getOldName() - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
getOne() - Method in class org.apache.hadoop.hive.ql.exec.Utilities.Tuple
 
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
 
getOpParseCtx() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpTaskMap() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getOpToParseCtxMap() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getOpToPartPruner() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpWalkerCtx
 
getOpToPartPruner() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpTreeSkel(Operator<?>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getOpType() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
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.plan.reduceSinkDesc
Returns the sort order of the key columns.
getOrderByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getOrdinal(int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils
Return an ordinal from an integer.
getOuterQueryLimit() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.joinDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.selectDesc
 
getOutputDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getOutputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
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.plan.createTableDesc
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getOutputFormatFinalPath(Path, JobConf, HiveOutputFormat<?, ?>, boolean, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
get the final output path of a given FileOutputFormat.
getOutputFormatSubstitute(Class<?>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
get a OutputFormat's substitute HiveOutputFormat
getOutputKeyColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
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 class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getOutputTableList() - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
getOutputTypes() - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getOutputValueColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
getOutStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
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
 
getParameterMetaData() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getParameterMetaData() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
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.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.ql.hooks.ReadEntity
Get the parameter map of the Entity.
getParameters() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getParameters() - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
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) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
 
getParentOperators() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getParentTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getParseInfo() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getParseTree() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
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.drop_partition_args
 
getPart_vals() - 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.append_partition_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.get_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.drop_partition_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getPartCols() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getPartCols() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getPartColsString() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getPartDesc() - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
getPartDir() - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
getPartDirPath() - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
getPartition(String, String, List<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, 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() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
Get partition entity.
getPartition() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Get the partition associated with the entity.
getPartition(Table, Map<String, String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns partition metadata
getPartitionCols() - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
getPartitionDesc(Partition) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getPartitionKeysIterator() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPartitionKeysSize() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPartitionName() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getPartitionNames(String, String, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartitionPath(String, 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
 
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
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.hadoop.hive.ql.plan.MsckDesc
 
getPartName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.descTableDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.partitionDesc
 
getPartSpecs() - Method in class org.apache.hadoop.hive.ql.plan.dropTableDesc
 
getPath() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
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
 
getPathToAliases() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
getPathToPartitionInfo() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
getPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.showFunctionsDesc
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.showTablesDesc
 
getPctx() - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
getPlan() - Method in class org.apache.hadoop.hive.ql.Driver
 
getPlan() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getPosBigTable() - Method in class org.apache.hadoop.hive.ql.plan.mapJoinDesc
 
getPosition() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
getPosition() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Returns the current position in the input.
getPosition() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Return the current byte position in the input file.
getPosition(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getPosition() - Method in class org.apache.hadoop.hive.ql.plan.explosionDesc
 
getPositionParent(MapJoinOperator, 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
 
getPosToAliasMap() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getPrecision(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getPredicate() - Method in class org.apache.hadoop.hive.ql.plan.filterDesc
 
getPrevious(Tuple) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.TupleBrowser
Get the previous tuple.
getPrimaryKeys(String, String, String) - Method in class org.apache.hadoop.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
 
getPrimitiveJavaClass() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
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.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.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.LazyVoidObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveJavaObjectInspector
 
getPrimitiveJavaObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
getPrimitiveJavaObject(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.primitive.StringObjectInspector
Get the String representation of the data.
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.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.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.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.
getPrimitiveObjectInspectorFromClass(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
Returns an ObjectInspector for a primitive Class.
getPrimitiveTypeInfo(String) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
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
 
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.LazyStringObjectInspector
 
getPrimitiveWritableObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveWritableObjectInspector
 
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.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.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.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 class org.apache.hadoop.hive.serde2.objectinspector.primitive.WritableStringObjectInspector
 
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.
getProcedureColumns(String, String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getProcedures(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getProcedureTerm() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getProcessor(TTransport) - Method in class org.apache.hadoop.hive.service.HiveServer.ThriftHiveProcessorFactory
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
Return the progress within the input split
getProperties() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getProperties() - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
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
getProperty
getPropertyInfo(String, Properties) - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
 
getProps() - 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
 
getProtocolFactoryByName(String) - Static method in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
getPrunedColList(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getPrunedColLists() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getPrunedPreds(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getQB() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getQB() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
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
 
getQuery() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
The query executed by Hive
getQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
getQueryDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getQueryFile() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getQueryRet() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Used to determine the status of a query, possibly why it failed
getQueryStr() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryTimeout() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getQueryTimeout() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getQueryTimeout() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getRandIntegerArray(Random) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.TestBinarySortableSerDe
 
getRandString(Random) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.TestBinarySortableSerDe
 
getReadColumnIDs(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Returns an array of column ids(start from zero) which is set in the given parameter conf.
getRealClass() - Method in interface org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContext
Produces the specific class to deserialize
getRealClass() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
 
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
 
getRecid() - Method in class org.apache.hadoop.hive.ql.util.jdbm.htree.HTree
Get the record identifier used to load this hashtable.
getRecordManager() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Get the underlying Record Manager.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.RCFileInputFormat
 
getRecordWriter(JobConf, HiveOutputFormat<?, ?>, Class<? extends Writable>, boolean, Properties, Path) - Static method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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.IgnoreKeyTextOutputFormat
Deprecated.  
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
getReduceKeyTableDesc(List<FieldSchema>, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor for reduce key.
getReducer() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
getReduceSinkDesc(ArrayList<exprNodeDesc>, ArrayList<exprNodeDesc>, List<String>, boolean, int, ArrayList<exprNodeDesc>, String, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
getReduceSinkDesc(ArrayList<exprNodeDesc>, ArrayList<exprNodeDesc>, List<String>, boolean, int, int, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
getReduceSinkMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getReduceSinkProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
The Factory method to get ColumnPrunerReduceSinkProc class.
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.
getRef(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getRef(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getRef(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getRef(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getReflectionObjectInspector(Type, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getReplace() - Method in class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
getRequiredness() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
Get the requiredness attribute of this field.
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.descFunctionDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.descTableDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.explainWork
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.showFunctionsDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.showPartitionsDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.showTablesDesc
 
getResFileString() - Method in class org.apache.hadoop.hive.ql.plan.descFunctionDesc
 
getResFileString() - Method in class org.apache.hadoop.hive.ql.plan.descTableDesc
 
getResFileString() - Method in class org.apache.hadoop.hive.ql.plan.showFunctionsDesc
 
getResFileString() - Method in class org.apache.hadoop.hive.ql.plan.showPartitionsDesc
 
getResFileString() - Method in class org.apache.hadoop.hive.ql.plan.showTablesDesc
 
getResolver() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getResolver() - Method in class org.apache.hadoop.hive.ql.exec.UDAF
Gets the resolver.
getResolver() - Method in class org.apache.hadoop.hive.ql.exec.UDF
Get the method resolver.
getResolverCtx() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getResourceFiles(Configuration, SessionState.ResourceType) - Static method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
getResultFile() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getResults(Vector<String>) - Method in class org.apache.hadoop.hive.ql.Driver
 
getResultsDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getResultSet() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getResultSet() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getResultSet() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getResultSetConcurrency() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getResultSetConcurrency() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getResultSetConcurrency() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getResultSetHoldability() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getResultSetHoldability() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getResultSetHoldability() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getResultSetHoldability() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getResultSetType() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getResultSetType() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getResultSetType() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
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
 
getReversedExprs() - Method in class org.apache.hadoop.hive.ql.plan.joinDesc
 
getRight() - Method in class org.apache.hadoop.hive.ql.parse.joinCond
 
getRight() - Method in class org.apache.hadoop.hive.ql.plan.joinCond
 
getRightAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getRoot(int) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Returns the indicated root rowid.
getRoot(int) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Returns the indicated root rowid.
getRoot(int) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Returns the indicated root rowid.
getRootCount() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Returns the number of slots available for "root" rowids.
getRootCount() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Returns the number of slots available for "root" rowids.
getRootCount() - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Returns the number of slots available for "root" rowids.
getRootMapJoinOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
getRootOps() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
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.parse.BaseSemanticAnalyzer
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.plan.explainWork
 
getRow() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getRowId(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getRowId(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getRowId(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getRowId(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getRowIdLifetime() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getRowResolver(Node) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getRowSeparator() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
getRowTypeInfo() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getRR() - Method in class org.apache.hadoop.hive.ql.parse.OpParseContext
 
getRSProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
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
 
getScale(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
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(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getSchema() - 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() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.descFunctionDesc
 
getSchema() - 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.showFunctionsDesc
 
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.service.HiveServer.HiveServerHandler
Return the Hive schema of the query result
getSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getSchema() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
getSchemaName(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getSchemas() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSchemas(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSchemaTerm() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getScriptCmd() - Method in class org.apache.hadoop.hive.ql.plan.scriptDesc
 
getScriptInputInfo() - Method in class org.apache.hadoop.hive.ql.plan.scriptDesc
 
getScriptOutputInfo() - Method in class org.apache.hadoop.hive.ql.plan.scriptDesc
 
getSCRProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getSd() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getSd() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getSearchStringEscape() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSecondarySeparator() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
getSeenFileSinkOps() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getSeenOps() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getSelectColsFromChildren(SelectOperator, List<String>) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
Creates the list of internal column names for select * expressions.
getSelectProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
The Factory method to get the ColumnPrunerSelectProc class.
getSelForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
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
 
getSeparators() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getSerDe() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator.MapJoinObjectCtx
 
getSerdeClassName() - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
getSerdeInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSerDeInfo() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getSerdeName() - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
getSerdeParam(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSerialization() - Method in interface org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContext
An Serialization object for objects of type S
getSerialization() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
Looks up and instantiates the Serialization Object Important to note here that we are not relying on the Hadoop SerializationFactory part of the Serialization framework.
getSerializationLib() - Method in class org.apache.hadoop.hive.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
 
getSerializationNullFormat() - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
Returns the Writable Class after serialization.
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 interface org.apache.hadoop.hive.serde2.Serializer
Returns the Writable class that would be returned by the serialize method.
getSerializedClass() - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
getSerName() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getSessionId() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getSessionId() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getSessionName() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
The session name is an identifier to recognize the session
getShort(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getShort(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getShort(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getShort(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getShort(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the short value out of a primitive object.
getShowFuncsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowPartsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowTblsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getSignature() - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
getSortByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Get the Sort By AST for the clause.
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.Table
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
getSortColsIterator() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSortColsSize() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSourceDir() - Method in class org.apache.hadoop.hive.ql.plan.loadDesc
 
getSp() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getSpec() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getSQLKeywords() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSQLStateType() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSQLXML(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getSQLXML(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getSQLXML(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getSQLXML(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getSrcForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getSrcForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getSs() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getSSIsSilent() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is a chained call to SessionState.getIsSilent()
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
 
getStandardObjectInspectors(Map<Byte, List<ObjectInspector>>) - Static method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
getStandardOI() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator.MapJoinObjectCtx
 
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
 
getStandardStructTypeName(StructObjectInspector) - 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.ql.io.HiveInputFormat.HiveInputSplit
The position of the first byte in the file to process.
getStart() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 
getState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getStatement() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
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.HiveMetaStore.HMSHandler
 
getStatus() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Return the status of the server
getStream() - Method in class org.apache.hadoop.hive.ql.Context
 
getStrExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get StrExprProcessor.
getString(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getString(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getString(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getString(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getStringFunctions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
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.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.UnionStructObjectInspector
 
getStructFieldRef(String) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
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.UnionStructObjectInspector
 
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.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.UnionStructObjectInspector
 
getStructFieldTypeInfo(String) - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getStructTypeInfo(List<String>, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getSubqAliases() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getSubqForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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.append_partition_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_fields_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_partitions_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_table_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.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.getSchema_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_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_partition_names_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_schema_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_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_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_partition_names_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_schema_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.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
 
getSuperTables(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSuperTypes(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSystemFunctions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
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.parse.SamplePruner
Gets the table alias
getTabAlias() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
getTabAliases() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getTable(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTable(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTable(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a table object.
getTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a table object.
getTable(Configuration, Properties) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getTable() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
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.ReadEntity
Get table entity.
getTable() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Get the table associated with the entity.
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() - Method in class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.descFunctionDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.descTableDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.showFunctionsDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.showPartitionsDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.showTablesDesc
 
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_schema_args
 
getTableDesc(Table) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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
 
getTableForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getTableInfo() - Method in class org.apache.hadoop.hive.ql.plan.fileSinkDesc
 
getTableName(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getTableName() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getTableName() - Method in exception org.apache.hadoop.hive.ql.metadata.InvalidTableException
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
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.dropTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
getTableNames() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getTablePrivileges(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getTables(String, String, String, String[]) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getTables(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTables(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTables(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getTables(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTables(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getTableSample() - Method in class org.apache.hadoop.hive.ql.parse.SamplePruner
Gets the parse information of the associated table sample clause
getTablesByPattern(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
returns all existing tables that match the given pattern.
getTableScanMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getTableScanProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerDefaultProc class.
getTablesForDb(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getTablesNotInMs() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
getTablesNotOnFs() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
getTableTypes() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getTabName() - Method in class org.apache.hadoop.hive.ql.plan.showPartitionsDesc
 
getTabNameForAlias(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.plan.reduceSinkDesc
 
getTagToValueDesc() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
getTargetDir() - Method in class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
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(HiveConf, Object) - Method in interface org.apache.hadoop.hive.ql.plan.ConditionalResolver
All conditional resolvers implement this interface
getTaskId(HiveConf, Object) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles
 
getTaskIdFromFilename(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get the task id from the filename.
getTaskInfoMap() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getTaskTmpDir() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
getTaskTmpDir() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
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_table_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.drop_partition_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_names_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_table_args
 
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
 
getTblDirPath() - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
getTemplate() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getTemplatePath() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getThriftSchema() - Method in class org.apache.hadoop.hive.ql.Driver
Get a Schema with fields represented with Thrift DDL types
getThriftSchema() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Return the Thrift schema of the query result
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.hadoop.hive.jdbc.HiveCallableStatement
 
getTime(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getTime(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getTime(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getTime(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getTime(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getTime(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getTime(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getTimeDateFunctions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getTimestamp(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getTimestamp(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getTimestamp(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getTimestamp(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getTimestamp(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getTimestamp(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getTimestamp(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getTimestamp(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getTmpDir() - Method in class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
getToken(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Get the specific Token.
getTokenNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getToPath() - Method in class org.apache.hadoop.hive.ql.plan.copyWork
 
getTopOps() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getTopSelOps() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getTopToTable() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getToRR() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
getTotalInputFileSize(JobConf, mapredWork) - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
Calculate the total size of input files.
getToWalk() - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
getTPartition() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getTransactionIsolation() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getTransactionManager() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Get the underlying Transaction Manager
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.aliasList_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.alterStatementSuffix_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.alterStatementSuffixDropPartitions_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.alterStatementSuffixRename_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.atomExpression_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.booleanValue_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.caseExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.castExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.charSetStringLiteral_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.clusterByClause_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.columnName_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.constant_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.createStatement_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.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.distributeByClause_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.dropStatement_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.explainStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.expression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.expressionList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.fromClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.fromSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.function_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.functionName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.groupByClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.groupByExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.hintArgName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.hintArgs_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.hintClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.hintItem_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.hintList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.hintName_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.insertClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.joinSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.joinToken_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.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.nullCondition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.orderByClause_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.partitionSpec_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.partitionVal_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.precedenceAmpersandExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceAmpersandOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceAndExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceAndOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceBitwiseOrExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceBitwiseOrOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceBitwiseXorExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceBitwiseXorOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceEqualExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceEqualOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceFieldExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceNotExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceNotOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceOrExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceOrOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedencePlusExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedencePlusOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceStarExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceStarOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceUnaryOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceUnaryPrefixExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceUnarySuffixExpression_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.propertiesList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.queryOperator_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.queryStatement_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.regular_body_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.searchCondition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.selectClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.selectExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.selectExpressionList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.selectItem_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.selectList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.serde_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.serdeFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.serdePropertiesFormat_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.sortByClause_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.subQuerySource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableAllColumns_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.tableOrColumn_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.tableProperties_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.tableSample_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tabName_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.trfmClause_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.whenExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.whereClause_return
 
getTreeAdaptor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getTSProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getTTable() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getTTDesc() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
getTTDesc() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getTwo() - Method in class org.apache.hadoop.hive.ql.exec.Utilities.Tuple
 
getType() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getType() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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(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.ColumnInfo
 
getType() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
Get the type.
getType() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Get the type of the entity.
getType() - Method in class org.apache.hadoop.hive.ql.plan.joinCond
 
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
 
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
 
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 a Primitive Writable Class.
getTypeInfo() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getTypeInfo() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
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
 
getTypeInfosFromTypeString(String) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
 
getTypeMap() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getTypeName(int) - Static method in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
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.LazySimpleStructObjectInspector
 
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.UnionStructObjectInspector
 
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.
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.
getTypeString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
getUCtx() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getUdafEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
getUDFClass() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
getUDFClass(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getUDFClass() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
getUDFInfo(Class<?>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getUDFMethod(String, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Get the UDF method for the name and argumentClasses.
getUDFMethod(String, TypeInfo...) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getUDFMethod() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
getUDTs(String, String, String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getUnderscore_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getUnicodeStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getUnicodeStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getUnionMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getUnionParseContext(UnionOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
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
 
getUnknownPartns() - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
get unknown partitions
getUnknownUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getUpdateCount() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getUpdateCount() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getUpdateCount() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getURL(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getURL(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getURL() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getURL(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getURL(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getUser() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getUser() - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
getUserName() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getUTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getValue() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeConstantDesc
 
getValue() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeNullDesc
 
getValue() - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Tuple
Get the value.
getValueClass() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getValueCols() - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
getValues() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getValues() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getValues() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getValueSerializeInfo() - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
getValuesIterator() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getValuesSize() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getValueTblDescs() - Method in class org.apache.hadoop.hive.ql.plan.mapJoinDesc
 
getValueType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
getVar(Configuration, HiveConf.ConfVars) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
getVar(HiveConf.ConfVars) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
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.service.HiveServer.HiveServerHandler
Return the version of the server software
getVersionColumns(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
GetVersionPref - Class in org.apache.hadoop.hive.ant
Implementation of the ant task .
GetVersionPref() - Constructor for class org.apache.hadoop.hive.ant.GetVersionPref
 
getView() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Returns the current view of the block.
getWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getWarnings() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
getWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
getWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
getWhrForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getWork() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getWritableObject() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
getWritableObject() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryPrimitive
 
GraphWalker - Interface in org.apache.hadoop.hive.ql.lib
Interface for operator graph walker.
GREATERTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
GREATERTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
GREATERTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
groupByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
groupByDesc - Class in org.apache.hadoop.hive.ql.plan
 
groupByDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.groupByDesc
 
groupByDesc(groupByDesc.Mode, ArrayList<String>, ArrayList<exprNodeDesc>, ArrayList<aggregationDesc>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.groupByDesc
 
groupByDesc.Mode - Enum in org.apache.hadoop.hive.ql.plan
 
groupByExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
GroupByOperator - Class in org.apache.hadoop.hive.ql.exec
GroupBy operator implementation.
GroupByOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.GroupByOperator
 

H

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.MiniDFSShim - Interface in org.apache.hadoop.hive.shims
Shim around the functions in MiniDFSCluster that Hive uses.
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 Listner interface function
hasColumnExpr(exprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Whether the expression contains a column node or not.
hashAggregations - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
hashCode() - Method in class org.apache.hadoop.hive.hwi.HWIAuth
HWIAuth is used in Map(s) the hashCode method is required
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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 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.MetaException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
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.Schema
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.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_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.append_partition_args
 
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.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_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_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.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_partition_args
 
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_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_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.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_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_partition_args
 
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_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_partitions_args
 
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_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_table_args
 
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_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.Type
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
hashCode() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
Hashcode function.
hashCode() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Hashcode function.
hashCode() - Method in class org.apache.hadoop.hive.ql.io.HiveKey
 
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.parse.InputSignature
 
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.ByteWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
hashCode(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
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.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.service.HiveClusterStatus
 
hashCode() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
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.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
 
hasPartitionPredicate(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
 
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.ExecDriver
 
hasReduce() - Method in class org.apache.hadoop.hive.ql.exec.MapRedTask
 
hasReduce() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
hasReduceTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.Driver
 
hasTableAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
Header() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
HeaderList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
HexDigit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
HexDigit - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hexString(BytesWritable) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.TestBinarySortableSerDe
 
hexString(BytesWritable) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
 
hintArgName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintArgs() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintItem() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
hintName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Hive - Class in org.apache.hadoop.hive.ql.metadata
The Hive class contains information about this instance of Hive.
HIVE_L4J - Static variable in class org.apache.hadoop.hive.ql.session.SessionState
 
HiveAlterHandler - Class in org.apache.hadoop.hive.metastore
Hive specific implementation of alter
HiveAlterHandler() - Constructor for class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
HiveCallableStatement - Class in org.apache.hadoop.hive.jdbc
 
HiveCallableStatement() - Constructor for class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
HiveClient - Class in org.apache.hadoop.hive.service
Thrift Hive Client Just an empty class that can be used to run queries on a stand alone hive server
HiveClient(TProtocol) - Constructor for class org.apache.hadoop.hive.service.HiveClient
 
HiveClusterStatus - Class in org.apache.hadoop.hive.service
 
HiveClusterStatus() - Constructor for class org.apache.hadoop.hive.service.HiveClusterStatus
 
HiveClusterStatus(int, int, int, int, int, int) - 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.
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.ConfVars - Enum in org.apache.hadoop.hive.conf
 
HiveConnection - Class in org.apache.hadoop.hive.jdbc
 
HiveConnection(String, Properties) - Constructor for class org.apache.hadoop.hive.jdbc.HiveConnection
TODO: - throw more specific exception - parse uri (use java.net.URI?)
HiveDatabaseMetaData - Class in org.apache.hadoop.hive.jdbc
 
HiveDatabaseMetaData() - Constructor for class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
HiveDataSource - Class in org.apache.hadoop.hive.jdbc
 
HiveDataSource() - Constructor for class org.apache.hadoop.hive.jdbc.HiveDataSource
 
HiveDriver - Class in org.apache.hadoop.hive.jdbc
 
HiveDriver() - Constructor for class org.apache.hadoop.hive.jdbc.HiveDriver
 
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
 
HiveFileFormatUtils - Class in org.apache.hadoop.hive.ql.io
An util class for various Hive file format tasks.
HiveFileFormatUtils() - Constructor for class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
hiveHist - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
HiveHistory - Class in org.apache.hadoop.hive.ql.history
 
HiveHistory(SessionState) - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory
Construct HiveHistory object an open history log file.
HiveHistory.Info - Class in org.apache.hadoop.hive.ql.history
 
HiveHistory.Info() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.Info
 
HiveHistory.Keys - Enum in org.apache.hadoop.hive.ql.history
 
HiveHistory.Listener - Interface in org.apache.hadoop.hive.ql.history
Listner interface Parser will call handle function for each record type
HiveHistory.QueryInfo - Class in org.apache.hadoop.hive.ql.history
 
HiveHistory.QueryInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
HiveHistory.RecordTypes - Enum in org.apache.hadoop.hive.ql.history
 
HiveHistory.SessionInfo - Class in org.apache.hadoop.hive.ql.history
 
HiveHistory.SessionInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.SessionInfo
 
HiveHistory.TaskInfo - Class in org.apache.hadoop.hive.ql.history
 
HiveHistory.TaskInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.TaskInfo
 
HiveHistoryViewer - Class in org.apache.hadoop.hive.ql.history
 
HiveHistoryViewer(String) - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
HiveIgnoreKeyTextOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
HiveIgnoreKeyTextOutputFormat replaces key with null before feeding the to TextOutputFormat.RecordWriter.
HiveIgnoreKeyTextOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
 
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
 
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
 
HiveInterface - Interface in org.apache.hadoop.hive.service
HiveInterface extends 2 interfaces, ThriftHive and ThriftHiveMetastore.
hiveJar - Variable in class org.apache.hadoop.hive.conf.HiveConf
 
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.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
 
HiveLexer() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveLexer
 
HiveLexer(CharStream) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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
 
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.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
 
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
 
HiveOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Interface in org.apache.hadoop.hive.ql.io
HiveOutputFormat describes the output-specification for Hive's operators.
HiveParser - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser(TokenStream) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser
 
HiveParser.aliasList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.aliasList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.aliasList_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.alterStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffix_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.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.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.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.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.atomExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.atomExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.atomExpression_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.booleanValue_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.booleanValue_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.booleanValue_return
 
HiveParser.caseExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.caseExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.caseExpression_return
 
HiveParser.castExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.castExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.castExpression_return
 
HiveParser.charSetStringLiteral_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.charSetStringLiteral_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.charSetStringLiteral_return
 
HiveParser.clusterByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.clusterByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.clusterByClause_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.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.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.constant_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.constant_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.constant_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.createStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createStatement_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.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.distributeByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.distributeByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.distributeByClause_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.dropStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropStatement_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.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.expression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.expression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.expression_return
 
HiveParser.expressionList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.expressionList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.expressionList_return
 
HiveParser.fromClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.fromClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.fromClause_return
 
HiveParser.fromSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.fromSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.fromSource_return
 
HiveParser.function_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.function_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.function_return
 
HiveParser.functionName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.functionName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.functionName_return
 
HiveParser.groupByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.groupByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.groupByClause_return
 
HiveParser.groupByExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.groupByExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.groupByExpression_return
 
HiveParser.hintArgName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.hintArgName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.hintArgName_return
 
HiveParser.hintArgs_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.hintArgs_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.hintArgs_return
 
HiveParser.hintClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.hintClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.hintClause_return
 
HiveParser.hintItem_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.hintItem_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.hintItem_return
 
HiveParser.hintList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.hintList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.hintList_return
 
HiveParser.hintName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.hintName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.hintName_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.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.joinSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.joinSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.joinSource_return
 
HiveParser.joinToken_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.joinToken_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.joinToken_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.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.nullCondition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.nullCondition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.nullCondition_return
 
HiveParser.orderByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.orderByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.orderByClause_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.partitionSpec_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.partitionSpec_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.partitionSpec_return
 
HiveParser.partitionVal_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.partitionVal_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.partitionVal_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.precedenceAmpersandExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceAmpersandExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceAmpersandExpression_return
 
HiveParser.precedenceAmpersandOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceAmpersandOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceAmpersandOperator_return
 
HiveParser.precedenceAndExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceAndExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceAndExpression_return
 
HiveParser.precedenceAndOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceAndOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceAndOperator_return
 
HiveParser.precedenceBitwiseOrExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceBitwiseOrExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceBitwiseOrExpression_return
 
HiveParser.precedenceBitwiseOrOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceBitwiseOrOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceBitwiseOrOperator_return
 
HiveParser.precedenceBitwiseXorExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceBitwiseXorExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceBitwiseXorExpression_return
 
HiveParser.precedenceBitwiseXorOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceBitwiseXorOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceBitwiseXorOperator_return
 
HiveParser.precedenceEqualExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceEqualExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceEqualExpression_return
 
HiveParser.precedenceEqualOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceEqualOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceEqualOperator_return
 
HiveParser.precedenceFieldExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceFieldExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceFieldExpression_return
 
HiveParser.precedenceNotExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceNotExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceNotExpression_return
 
HiveParser.precedenceNotOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceNotOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceNotOperator_return
 
HiveParser.precedenceOrExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceOrExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceOrExpression_return
 
HiveParser.precedenceOrOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceOrOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceOrOperator_return
 
HiveParser.precedencePlusExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedencePlusExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedencePlusExpression_return
 
HiveParser.precedencePlusOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedencePlusOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedencePlusOperator_return
 
HiveParser.precedenceStarExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceStarExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceStarExpression_return
 
HiveParser.precedenceStarOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceStarOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceStarOperator_return
 
HiveParser.precedenceUnaryOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceUnaryOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceUnaryOperator_return
 
HiveParser.precedenceUnaryPrefixExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceUnaryPrefixExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceUnaryPrefixExpression_return
 
HiveParser.precedenceUnarySuffixExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.precedenceUnarySuffixExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.precedenceUnarySuffixExpression_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.propertiesList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.propertiesList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.propertiesList_return
 
HiveParser.queryOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.queryOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.queryOperator_return
 
HiveParser.queryStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.queryStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.queryStatement_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.regular_body_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.regular_body_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.regular_body_return
 
HiveParser.searchCondition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.searchCondition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.searchCondition_return
 
HiveParser.selectClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectClause_return
 
HiveParser.selectExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectExpression_return
 
HiveParser.selectExpressionList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectExpressionList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectExpressionList_return
 
HiveParser.selectItem_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectItem_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectItem_return
 
HiveParser.selectList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectList_return
 
HiveParser.serde_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.serde_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.serde_return
 
HiveParser.serdeFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.serdeFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.serdeFormat_return
 
HiveParser.serdePropertiesFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.serdePropertiesFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.serdePropertiesFormat_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.sortByClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.sortByClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.sortByClause_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.subQuerySource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.subQuerySource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.subQuerySource_return
 
HiveParser.tableAllColumns_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableAllColumns_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableAllColumns_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.tableOrColumn_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableOrColumn_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableOrColumn_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.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.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.tableSample_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableSample_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableSample_return
 
HiveParser.tableSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableSource_return
 
HiveParser.tabName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tabName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tabName_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.trfmClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.trfmClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.trfmClause_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.whenExpression_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.whenExpression_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.whenExpression_return
 
HiveParser.whereClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.whereClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.whereClause_return
 
HivePreparedStatement - Class in org.apache.hadoop.hive.jdbc
 
HivePreparedStatement(JdbcSessionState, HiveInterface, String) - Constructor for class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
HiveRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
 
HiveRecordReader(RecordReader) - Constructor for class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
HiveResultSet - Class in org.apache.hadoop.hive.jdbc
 
HiveResultSet(HiveInterface, int) - Constructor for class org.apache.hadoop.hive.jdbc.HiveResultSet
 
HiveResultSet(HiveInterface) - Constructor for class org.apache.hadoop.hive.jdbc.HiveResultSet
 
HiveResultSetMetaData - Class in org.apache.hadoop.hive.jdbc
 
HiveResultSetMetaData(List<String>, List<String>) - Constructor for class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
HiveSequenceFileOutputFormat - Class in org.apache.hadoop.hive.ql.io
A HiveOutputFormat that writes SequenceFiles.
HiveSequenceFileOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
 
HiveServer - Class in org.apache.hadoop.hive.service
Thrift Hive Server Implementation
HiveServer() - Constructor for class org.apache.hadoop.hive.service.HiveServer
 
HiveServer.HiveServerHandler - Class in org.apache.hadoop.hive.service
Handler which implements the Hive Interface This class can be used in lieu of the HiveClient class to get an embedded server
HiveServer.HiveServerHandler() - Constructor for class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
A constructor.
HiveServer.ThriftHiveProcessorFactory - Class in org.apache.hadoop.hive.service
 
HiveServer.ThriftHiveProcessorFactory(TProcessor) - Constructor for class org.apache.hadoop.hive.service.HiveServer.ThriftHiveProcessorFactory
 
HiveServerException - Exception in org.apache.hadoop.hive.service
 
HiveServerException() - Constructor for exception org.apache.hadoop.hive.service.HiveServerException
 
HiveServerException(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.
HiveStatement - Class in org.apache.hadoop.hive.jdbc
 
HiveStatement(JdbcSessionState, HiveInterface) - Constructor for class org.apache.hadoop.hive.jdbc.HiveStatement
 
HiveUtils - Class in org.apache.hadoop.hive.ql.metadata
General collection of helper functions
HiveUtils() - Constructor for class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
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 - Variable in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
 
HTree - Class in org.apache.hadoop.hive.ql.util.jdbm.htree
Persistent hashtable implementation for PageManager.
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() - 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() - 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
 

I

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
 
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 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
idToTableNameMap - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
ifNotExists() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
IgnoreKeyTextOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
Deprecated. use HiveIgnoreKeyTextOutputFormat instead}
IgnoreKeyTextOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat
Deprecated.  
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.  
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
TODO Unnecessary when the server sides for both dbstore and filestore are merged
implicitConvertable(TypeInfo, TypeInfo) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether it is possible to implicitly convert an object of Class from to Class to.
in - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
inBuf - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
Include() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
Index - Class in org.apache.hadoop.hive.metastore.api
 
Index() - Constructor for class org.apache.hadoop.hive.metastore.api.Index
 
Index(String, int, String, String, List<String>, String) - 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.serde2.thrift.TCTLSeparatedProtocol
An index into what column we're on
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.
INDEXNAME - Static variable in class org.apache.hadoop.hive.metastore.api.Index
 
INDEXTYPE - Static variable in class org.apache.hadoop.hive.metastore.api.Index
 
init() - Method in interface org.apache.hadoop.hive.ql.exec.UDAFEvaluator
Initializer.
init(JobConf) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
init(ParseContext) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluator
 
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.GenericUDAFCount.GenericUDAFCountEvaluator
 
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.GenericUDAFSum.GenericUDAFSumDouble
 
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.UDAFAvg.UDAFAvgEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFCount.UDAFCountEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxDoubleEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxFloatEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxIntEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxLongEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxShortEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxStringEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinDoubleEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinFloatEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinIntEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinLongEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinShortEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinStringEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFSum.UDAFSumEvaluator
 
init(BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStruct
 
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.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.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.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
Set the data for this LazyObject.
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(List<String>, List<ObjectInspector>, byte, Text, boolean, boolean, byte) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
init(List<StructField>, byte, Text) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
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.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.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.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.LazyBinaryObject
Set the data for this LazyBinaryObject.
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(List<String>, List<ObjectInspector>) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
init(List<StructField>) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
initDynamicSerde() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
Instantiate the dynamic serde used to deserialize the result row
initEvaluators(ExprNodeEvaluator[], ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.Operator
Initialize an array of ExprNodeEvaluator 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.
initHiveLog4j() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
Initialization when invoked from QL
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.ExprNodeFieldEvaluator
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeFuncEvaluator
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeNullEvaluator
 
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
initialize(Configuration, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Initializes operators only if all parents have been initialized.
initialize(HiveConf) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
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.mapredWork
 
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.GenericUDFCase
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFElt
 
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.GenericUDFIndex
 
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.GenericUDFLocate
 
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.GenericUDFSize
 
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.GenericUDFWhen
 
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(Configuration, Properties) - Method in interface org.apache.hadoop.hive.serde2.Deserializer
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 interface org.apache.hadoop.hive.serde2.Serializer
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
 
initializeAsRoot(Configuration, mapredWork) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
Initializes this map op as the root of the tree.
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
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.ExtractOperator
 
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.GroupByOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
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.Operator
Operator specific initialization.
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.UnionOperator
UnionOperator will transform the input rows if the inputObjInspectors from different parents are different.
INITIALIZING - Static variable in class org.apache.hadoop.hive.service.JobTrackerState
 
initLazyObject(LazyObject, byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
Initialize the LazyObject with the parameters, wrapping the byte[] automatically.
initMapJoinPlan(Operator<? extends Serializable>, GenMRProcContext, boolean, boolean, boolean, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Initialize the current plan by adding it to root tasks
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
initSerDe() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
initSerdeParams(Configuration, Properties, String) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
initUnionPlan(ReduceSinkOperator, GenMRProcContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Initialize the current union plan.
initUnionPlan(GenMRProcContext, Task<? extends Serializable>, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
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
 
innerIndex - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
An index into what field within a column we're on
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.
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_stream - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
 
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
 
INPUTFORMAT - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
InputFormatChecker - Interface in org.apache.hadoop.hive.ql.io
Check for validity of the input files.
inputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
inputFormatValidateInput(InputFormat, JobConf) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Calls fmt.validateInput(conf) if such a function exists.
inputObjInspectors - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
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
 
inputStream - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
inSample(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Sample
Given an arbitrary object, determine if it falls within this sample.
insert(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Inserts a new record using standard java object serialization.
insert(Object, Serializer) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Inserts a new record using a custom serializer.
insert(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Inserts a new record using a custom serializer.
insert(Object, Serializer) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Inserts a new record using a custom serializer.
insert(Object) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Inserts a new record using standard java object serialization.
insert(Object, Serializer) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Inserts a new record using a custom serializer.
insertClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
insertRow() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
insertsAreDetected(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
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
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.helper.ByteArraySerializer
Static instance.
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.helper.DefaultSerializer
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.helper.IntegerSerializer
 
INSTANCE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.helper.LongSerializer
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.EnumDelegate
 
INT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
IntegerComparator - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Comparator for Integer objects.
IntegerComparator() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.IntegerComparator
 
IntegerSerializer - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Optimized serializer for integers.
IntegerSerializer() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.IntegerSerializer
Construct an IntegerSerializer.
internalInitialize() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Sets the internal separator patterns and creates the internal tokenizer.
internalWriteString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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
 
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.
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
 
intWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
 
intWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
intWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
invalidate(long) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.recman.RecordCache
Notification to invalidate content related to given record.
invalidateAll() - Method in interface org.apache.hadoop.hive.ql.util.jdbm.recman.RecordCache
Notification to invalidate content of all records.
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.
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.
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
 
InvalidTableException(String, String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.InvalidTableException
 
InvalidTableException(Throwable, String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.InvalidTableException
 
InvalidTableException(String, Throwable, String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.InvalidTableException
 
invoke(Method, Object, Object...) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
iprot_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
is_table_exists(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
isActiveTransaction() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
isAfterLast() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
isAggFunction() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isAutoIncrement(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isBeforeFirst() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
isCandidate(exprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Returns true if the specified expression is pushdown candidate else false
isCaseSensitive(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isCatalogAtStart() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
isClosed() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
isClosed() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
isClosed() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
isClosed() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
isClosed() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
isCompressed() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isCompressed() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
isCurrency(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isDefinitelyWritable(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
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_table_args
 
isDeterministic() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
isDir(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
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.primitive.LazyStringObjectInspector
 
isExt() - Method in class org.apache.hadoop.hive.ql.plan.descTableDesc
 
isExtended() - Method in class org.apache.hadoop.hive.ql.plan.descFunctionDesc
 
isExternal() - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
isExternal() - Method in class org.apache.hadoop.hive.ql.plan.createTableLikeDesc
 
isFileContentEqual(File, File) - Method in class org.apache.hadoop.hive.hwi.TestHWISessionManager
 
isFirst() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
isGoOn() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
isInvalid() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
isJoinToken(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
Tests whether the parse tree node is a join token
isLast() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
isLastColumnTakesRest() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
isList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
isList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
isLocal() - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
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?
isMapOnlySubq() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.MapRedTask
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isMapSideJoin() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
isMRTmpFileURI(String) - Method in class org.apache.hadoop.hive.ql.Context
check if path is tmp path.
isNative() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isNativeSerDe(String) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
isNullable(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isOperator() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isPartitioned() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isPartitionKey(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isPoolable() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
isPoolable() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
isPoolable() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
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
 
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.
isPrimitiveWritableClass(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Whether the class is a Hive Primitive Writable class.
isReadOnly() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
isReadOnly() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
isReadOnly(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isRealThrift - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
Indicates whether fields can be out of order or missing.
isRedundantConversionFunction(ASTNode, boolean, ArrayList<exprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
isRunnable() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeConstantDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeNullDesc
 
isSearchable(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isSelectStar() - Method in class org.apache.hadoop.hive.ql.plan.selectDesc
 
isSelectStarQuery() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
isSelectStarQuery() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isSelStarNoCompute() - Method in class org.apache.hadoop.hive.ql.plan.selectDesc
 
isSet(int) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isSet(int) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
isSet(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
isSet(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
isSet(int) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
isSet(int) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
isSet(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
isSet(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
isSet(int) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
isSet(int) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
isSet(int) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
isSet(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
isSet(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
isSet(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
isSet(int) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
isSet(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
isSetAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
isSetAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
isSetBucketCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetCol() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
isSetColNames() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isSetCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetComment() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
isSetComments() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
isSetCompressed() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
isSetDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
isSetDescription() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
isSetField0() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
isSetField1() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
isSetField2() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
isSetField3() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
isSetFields() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
isSetFieldSchemas() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
isSetIndexName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isSetIndexType() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isSetInputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetLint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
isSetLintString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
isSetLocation() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
isSetMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
isSetMaxMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
isSetMaxReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
isSetMessage() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
isSetMStringString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
isSetMyint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
isSetMyString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
isSetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
isSetNumBuckets() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetNumRows() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
isSetOrder() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
isSetOutputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetOwner() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
isSetPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetPartName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isSetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
isSetProperties() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
isSetQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
isSetReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
isSetRetention() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetSerdeInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetSerializationLib() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
isSetSortCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isSetState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
isSetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
isSetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
isSetTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
isSetTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
isSetType1() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
isSetType2() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
isSetUnderscore_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
isSetValues() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
isSetVersion() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
isSigned(int) - Method in class org.apache.hadoop.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
 
isSkippable() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeField
 
isSplittable(FileSystem, Path) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_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.drop_database_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_type_result
 
isTempPath(FileStatus) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Detect if the supplied file is a temporary path
isUseJSONSerialize() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
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.
isValid(int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
isValidSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
isWritable(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
itemInit() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is the initialization process that is carried out for each SessionItem.
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluator
 
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.GenericUDAFCount.GenericUDAFCountEvaluator
 
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.GenericUDAFSum.GenericUDAFSumDouble
 
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(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFAvg.UDAFAvgEvaluator
 
iterate(Object) - Method in class org.apache.hadoop.hive.ql.udf.UDAFCount.UDAFCountEvaluator
 
iterate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxDoubleEvaluator
 
iterate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxFloatEvaluator
 
iterate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxIntEvaluator
 
iterate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxLongEvaluator
 
iterate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxShortEvaluator
 
iterate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxStringEvaluator
 
iterate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinDoubleEvaluator
 
iterate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinFloatEvaluator
 
iterate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinIntEvaluator
 
iterate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinLongEvaluator
 
iterate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinShortEvaluator
 
iterate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinStringEvaluator
 
iterate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFSum.UDAFSumEvaluator
 
IterationException - Exception in org.apache.hadoop.hive.ql.util.jdbm.helper
Iteration exception.
IterationException(String, Exception) - Constructor for exception org.apache.hadoop.hive.ql.util.jdbm.helper.IterationException
Construct a new iteration exception wrapping an underlying exception and providing a message.
IterationException(String) - Constructor for exception org.apache.hadoop.hive.ql.util.jdbm.helper.IterationException
Construct a new iteration exception with a message.
IterationException(Exception) - Constructor for exception org.apache.hadoop.hive.ql.util.jdbm.helper.IterationException
Construct a new iteration exception wrapping an underlying exception.

J

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
 
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
 
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
 
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
 
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
 
JavaStringObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaStringObjectInspector inspects a Java String Object.
javaStringObjectInspector - 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
JavaUtils() - Constructor for class org.apache.hadoop.hive.common.JavaUtils
 
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
 
jdbcCompliant() - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
Returns whether the driver is JDBC compliant.
JdbcSessionState - Class in org.apache.hadoop.hive.jdbc
 
JdbcSessionState() - Constructor for class org.apache.hadoop.hive.jdbc.JdbcSessionState
 
JdbcSessionState(HiveConf) - Constructor for class org.apache.hadoop.hive.jdbc.JdbcSessionState
 
JdbcSessionState(HiveConf, Hive) - Constructor for class org.apache.hadoop.hive.jdbc.JdbcSessionState
 
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
 
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.ExecDriver
 
jobClose(Configuration, boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
jobInfo(RunningJob) - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
from StreamJob.java
jobProgress(JobClient, RunningJob) - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
from StreamJob.java
JobTrackerState - Class in org.apache.hadoop.hive.service
 
JobTrackerState() - Constructor for class org.apache.hadoop.hive.service.JobTrackerState
 
join() - Method in interface org.apache.hadoop.hive.shims.JettyShims.Server
 
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 - Class in org.apache.hadoop.hive.ql.plan
Join conditions Descriptor implementation.
joinCond() - Constructor for class org.apache.hadoop.hive.ql.plan.joinCond
 
joinCond(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.plan.joinCond
 
joinCond(joinCond) - Constructor for class org.apache.hadoop.hive.ql.plan.joinCond
 
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>>, ArrayList<String>, boolean, joinCond[]) - Constructor for class org.apache.hadoop.hive.ql.plan.joinDesc
 
joinDesc(Map<Byte, List<exprNodeDesc>>, ArrayList<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.joinDesc
 
joinDesc(Map<Byte, List<exprNodeDesc>>, ArrayList<String>, joinCond[]) - Constructor for class org.apache.hadoop.hive.ql.plan.joinDesc
 
joinKeys - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
The expressions for join inputs's join keys.
joinKeysObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
The ObjectInspectors for the join inputs's join keys.
joinKeysStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
The standard 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
 
joinPlan(Operator<? extends Serializable>, Task<? extends Serializable>, Task<? extends Serializable>, GenMRProcContext, int, boolean, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Merge the current task with the task for the current reducer
joinSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
joinToken() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
joinType - Enum in org.apache.hadoop.hive.ql.parse
 
joinValues - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The expressions for join outputs.
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.

K

keyEval - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
The evaluators for the key columns.
keyFields - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
keyObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
keyObjects - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
keys() - Method in class org.apache.hadoop.hive.ql.util.jdbm.htree.HTree
Returns an enumeration of the keys contained in this
keysCurrentGroup - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
keyValueProperty() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
killIt() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is a callback style function used by the HiveSessionManager.
kind - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.Token
An integer that describes the kind of this token.
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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_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_RCFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RCFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_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_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_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_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_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_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_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_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_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_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_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_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_SEQUENCEFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SEQUENCEFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_TEXTFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TEXTFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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
 

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.ExecMapper
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.ExecReducer
 
LA(int) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.ANTLRNoCaseStringStream
 
last() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
LASTACCESSTIME - Static variable in class org.apache.hadoop.hive.metastore.api.Partition
 
LASTACCESSTIME - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
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
 
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.
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.
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
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() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryFactory
 
LazyBinaryFloat - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryObject for float which takes four bytes.
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(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(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(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.
LazyBinaryObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.lazybinary.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
LazyBinaryObjectInspectorFactory() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.objectinspector.LazyBinaryObjectInspectorFactory
 
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
 
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.
LazyBinaryStructObjectInspector - Class in org.apache.hadoop.hive.serde2.lazybinary.objectinspector
ObjectInspector for LazyBinaryStruct
LazyBinaryStructObjectInspector(List<String>, List<ObjectInspector>) - 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
 
LazyBinaryUtils - Class in org.apache.hadoop.hive.serde2.lazybinary
 
LazyBinaryUtils() - Constructor for class 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
 
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.
lazyBooleanObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
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.
lazyByteObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
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.
lazyDoubleObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LazyFactory - Class in org.apache.hadoop.hive.serde2.lazy
 
LazyFactory() - Constructor for class 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.
lazyFloatObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
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.
lazyIntObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LazyListObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
LazyListObjectInspector works on array data that is stored in LazyArray.
LazyListObjectInspector(ObjectInspector, byte, Text, boolean, byte) - 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.
lazyLongObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
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(ObjectInspector, ObjectInspector, byte, byte, Text, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
Call ObjectInspectorFactory.getStandardListObjectInspector instead.
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.
LazyObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
LazyObjectInspectorFactory() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
 
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.
LazyPrimitiveObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
LazyPrimitiveObjectInspectorFactory is the primary way to create new ObjectInspector instances.
LazyPrimitiveObjectInspectorFactory() - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
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 - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LazyShortObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableShortObjectInspector inspects a ShortWritable Object.
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
 
LazySimpleSerDe.SerDeParameters - Class in org.apache.hadoop.hive.serde2.lazy
 
LazySimpleSerDe.SerDeParameters() - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
LazySimpleStructObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
LazySimpleStructObjectInspector works on struct data that is stored in LazyStruct.
LazySimpleStructObjectInspector(List<String>, List<ObjectInspector>, byte, Text, boolean, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
Call ObjectInspectorFactory.getLazySimpleStructObjectInspector instead.
LazySimpleStructObjectInspector(List<StructField>, byte, Text) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
LazySimpleStructObjectInspector.MyField - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
 
LazySimpleStructObjectInspector.MyField(int, String, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector.MyField
 
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.
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.
LazyUtils - Class in org.apache.hadoop.hive.serde2.lazy
 
LazyUtils() - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyUtils
 
lazyVoidObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LazyVoidObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableVoidObjectInspector inspects a NullWritable Object.
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
 
LEFT_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.joinDesc
 
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.LazyBinaryUtils.VInt
 
length - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VLong
 
LESSTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LESSTHAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LESSTHANOREQUALTO - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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 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.
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
 
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
 
limitDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
line - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
LINE_DELIM - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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
 
lint - Variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
LINT - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
lintString - Variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
LINTSTRING - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
LIST_COLUMN_TYPES - Static variable in class org.apache.hadoop.hive.serde.Constants
 
LIST_COLUMNS - Static variable in class org.apache.hadoop.hive.serde.Constants
 
list_resource(SessionState.ResourceType, List<String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
LIST_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
ListObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
 
listPartitionNames(String, 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, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPartitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitions(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
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(RecordManager, long) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.htree.HTree
Load a persistent hashtable
loadDesc - Class in org.apache.hadoop.hive.ql.plan
 
loadDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.loadDesc
 
loadDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.loadDesc
 
loadFileDesc - Class in org.apache.hadoop.hive.ql.plan
 
loadFileDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
loadFileDesc(String, String, boolean, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
loadPartition(Path, String, AbstractMap<String, String>, boolean, Path) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Load a directory into a Hive Table Partition - Alters existing content of the partition with the contents of loadPath.
LoadSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
 
LoadSemanticAnalyzer(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, Path) - 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() - Constructor for class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
loadTableDesc(String, String, tableDesc, HashMap<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
loadTableDesc(String, String, tableDesc, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
LOCATION - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
locatorsUpdateCopy() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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.CommonJoinOperator
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
LOG - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveMetaStoreChecker
 
LOG - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
LOG - Static variable in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
 
LOG - Static variable in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
LOG - Static variable in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
 
LOG - Static variable in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
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 - Variable in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.binarysortable.BinarySortableSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
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.LazySimpleStructObjectInspector
 
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.StandardStructObjectInspector
 
LOG - Static variable in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
 
logDirectory - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
logExpr(Node, ExprWalkerInfo) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
 
logFile - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
LOGFILE_HEADER - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Magic for transaction file
logStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
logVars(PrintStream) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
LongComparator - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Comparator for java.lang.Long objects.
LongComparator() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.LongComparator
 
LongObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A LongObjectInspector inspects an Object representing a Long.
LongSerializer - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Optimized serializer for long integers.
LongSerializer() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.LongSerializer
Construct a LongSerializer.
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
 
longWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
 
longWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
longWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
longWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFOPLongDivide
 
lookupDeserializer(String) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
LPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
LSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
lString - Variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
LSTRING - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 

M

Magic - Interface in org.apache.hadoop.hive.ql.util.jdbm.recman
This interface contains magic cookies.
main(String[]) - Static method in class org.apache.hadoop.hive.cli.CliDriver
 
main(String[]) - Static method in class org.apache.hadoop.hive.hwi.HWIServer
 
main(String[]) - Static method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
main(String[]) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Conversion
Test static methods
main(String[]) - Static method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
main(String[]) - Static method in class org.apache.hadoop.hive.serde2.thrift_test.CreateSequenceFile
 
main(String[]) - Static method in class org.apache.hadoop.hive.service.HiveServer
 
makeDir(Path, HiveConf) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
makeHashMap(String...) - Static method in class org.apache.hadoop.hive.serde2.binarysortable.TestBinarySortableSerDe
 
makeHashMap(String...) - Static method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
 
makeList(Object...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
makeMap(Object...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
makePartName(Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
makePartName(List<FieldSchema>, List<String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
makeProperties(String...) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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.
makeSpecFromName(String) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
mAMPERSAND() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
map(Object, Object, OutputCollector, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapper
 
MAP_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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(Map<Byte, List<exprNodeDesc>>, tableDesc, Map<Byte, List<exprNodeDesc>>, List<tableDesc>, ArrayList<String>, int, joinCond[]) - Constructor for class org.apache.hadoop.hive.ql.plan.mapJoinDesc
 
MapJoinFactory - Class in org.apache.hadoop.hive.ql.optimizer
Operator factory for MapJoin processing
MapJoinFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
MapJoinFactory.MapJoin - Class in org.apache.hadoop.hive.ql.optimizer
MapJoin followed by Select
MapJoinFactory.MapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.MapJoin
 
MapJoinFactory.MapJoinMapJoin - Class in org.apache.hadoop.hive.ql.optimizer
MapJoin followed by MapJoin
MapJoinFactory.MapJoinMapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.MapJoinMapJoin
 
MapJoinFactory.ReduceSinkMapJoin - Class in org.apache.hadoop.hive.ql.optimizer
ReduceSink followed by MapJoin
MapJoinFactory.ReduceSinkMapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.ReduceSinkMapJoin
 
MapJoinFactory.TableScanMapJoin - Class in org.apache.hadoop.hive.ql.optimizer
TableScan followed by MapJoin
MapJoinFactory.TableScanMapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.TableScanMapJoin
 
MapJoinFactory.UnionMapJoin - Class in org.apache.hadoop.hive.ql.optimizer
Union followed by MapJoin
MapJoinFactory.UnionMapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.UnionMapJoin
 
MapJoinObjectKey - Class in org.apache.hadoop.hive.ql.exec
Map Join Object used for both key
MapJoinObjectKey() - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
MapJoinObjectKey(int, ArrayList<Object>) - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
MapJoinObjectValue - Class in org.apache.hadoop.hive.ql.exec
Map Join Object used for both key and value
MapJoinObjectValue() - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
MapJoinObjectValue(int, ArrayList<ArrayList<Object>>) - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
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.MapJoinObjectCtx - Class in org.apache.hadoop.hive.ql.exec
 
MapJoinOperator.MapJoinObjectCtx(ObjectInspector, SerDe) - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinOperator.MapJoinObjectCtx
 
MapJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of one of the rule-based map join optimization.
MapJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
empty constructor
MapJoinProcessor.CurrentMapJoin - Class in org.apache.hadoop.hive.ql.optimizer
 
MapJoinProcessor.CurrentMapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.CurrentMapJoin
 
MapJoinProcessor.Default - Class in org.apache.hadoop.hive.ql.optimizer
 
MapJoinProcessor.Default() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.Default
 
MapJoinProcessor.MapJoinDefault - Class in org.apache.hadoop.hive.ql.optimizer
 
MapJoinProcessor.MapJoinDefault() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinDefault
 
MapJoinProcessor.MapJoinFS - Class in org.apache.hadoop.hive.ql.optimizer
 
MapJoinProcessor.MapJoinFS() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinFS
 
MapJoinProcessor.MapJoinWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer
 
MapJoinProcessor.MapJoinWalkerCtx(List<MapJoinOperator>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
mapJoinTables - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
MAPKEY_DELIM - Static variable in class org.apache.hadoop.hive.serde.Constants
 
MapObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
 
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
 
mapPattern - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
mapredLocalWork - Class in org.apache.hadoop.hive.ql.plan
 
mapredLocalWork() - Constructor for class org.apache.hadoop.hive.ql.plan.mapredLocalWork
 
mapredLocalWork(LinkedHashMap<String, Operator<? extends Serializable>>, LinkedHashMap<String, fetchWork>) - Constructor for class org.apache.hadoop.hive.ql.plan.mapredLocalWork
 
MapRedTask - Class in org.apache.hadoop.hive.ql.exec
Alternate implementation (to ExecDriver) of spawning a mapreduce task that runs it from a separate jvm.
MapRedTask() - Constructor for class org.apache.hadoop.hive.ql.exec.MapRedTask
 
mapredWork - Class in org.apache.hadoop.hive.ql.plan
 
mapredWork() - Constructor for class org.apache.hadoop.hive.ql.plan.mapredWork
 
mapredWork(String, LinkedHashMap<String, ArrayList<String>>, LinkedHashMap<String, partitionDesc>, LinkedHashMap<String, Operator<? extends Serializable>>, tableDesc, List<tableDesc>, Operator<?>, Integer, mapredLocalWork) - Constructor for class org.apache.hadoop.hive.ql.plan.mapredWork
 
mapSeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
MAPTASKS - Static variable in class org.apache.hadoop.hive.service.HiveClusterStatus
 
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.
matchFilesOrDir(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
MAX_BLOCKS - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Maximum number of blocks in a file, leaving room for a 16 bit offset encoded within a long.
MAX_PARTS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
MAX_PARTS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
MAXMAPTASKS - Static variable in class org.apache.hadoop.hive.service.HiveClusterStatus
 
maxNextCharInd - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
MAXREDUCETASKS - Static variable in class org.apache.hadoop.hive.service.HiveClusterStatus
 
mBITWISEOR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mBITWISEXOR() - 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
 
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) - Constructor for class org.apache.hadoop.hive.metastore.model.MDatabase
To create a database object
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
 
mEQUAL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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.GenericUDAFAverageEvaluator
 
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.GenericUDAFCount.GenericUDAFCountEvaluator
 
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.GenericUDAFSum.GenericUDAFSumDouble
 
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(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDAFAvg.UDAFAvgEvaluator
 
merge(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFCount.UDAFCountEvaluator
 
merge(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxDoubleEvaluator
 
merge(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxFloatEvaluator
 
merge(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxIntEvaluator
 
merge(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxLongEvaluator
 
merge(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxShortEvaluator
 
merge(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxStringEvaluator
 
merge(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinDoubleEvaluator
 
merge(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinFloatEvaluator
 
merge(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinIntEvaluator
 
merge(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinLongEvaluator
 
merge(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinShortEvaluator
 
merge(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinStringEvaluator
 
merge(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFSum.UDAFSumEvaluator
 
mergeUniqElems(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
mergeWithChildrenPred(Node, OpWalkerInfo, ExprWalkerInfo, Set<String>, boolean) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
Take current operators pushdown predicates and merges them with children's pushdown predicates
MESSAGE - Static variable in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
MESSAGE - Static variable in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
MESSAGE - Static variable in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
MESSAGE - Static variable in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
MESSAGE - Static variable in exception org.apache.hadoop.hive.metastore.api.MetaException
 
MESSAGE - Static variable in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
MESSAGE - Static variable in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
MESSAGE - Static variable in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
MESSAGE - Static variable in exception org.apache.hadoop.hive.service.HiveServerException
 
META_TABLE_COLUMN_TYPES - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
META_TABLE_COLUMNS - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
META_TABLE_DB - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
META_TABLE_LOCATION - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
META_TABLE_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
META_TABLE_NAME - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
META_TABLE_PARTITION_COLUMNS - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
META_TABLE_SERDE - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
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.
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Database
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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 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.MetaException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
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.Schema
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
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.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_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.append_partition_args
 
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.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_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_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.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_partition_args
 
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_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_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.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_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_partition_args
 
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_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_partitions_args
 
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_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_table_args
 
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_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.Type
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Version
 
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.service.HiveClusterStatus
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.service.HiveServerException
 
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.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
 
metadataTag - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
metadataTag - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
MetadataTypedColumnsetSerDe - Class in org.apache.hadoop.hive.serde2
 
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.
metastoreCheck() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
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
 
mGREATERTHAN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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.ql.parse.HiveLexer
 
mightBeUnknown(exprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
 
MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MINUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
mismatch(IntStream, int, BitSet) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveParserX
 
mkdirs(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
mKW_ADD() - 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.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_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_CASE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CAST() - 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_COLUMNS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COMMENT() - 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_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_DATE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DATETIME() - 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_DESC() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DESCRIBE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DIRECTORY() - 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_END() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ESCAPED() - 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_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_FLOAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FORMAT() - 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_IF() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_IN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INPATH() - 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_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_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_LEFT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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_LONG() - 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_MINUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_MSCK() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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_ON() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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_OUTPUTFORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OVERWRITE() - 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_PLUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PROCEDURE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PROPERTIES() - 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_RCFILE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_READ() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_READS() - 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_RENAME() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REPLACE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REVOKE() - 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_ROW() - 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_SELECT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SEQUENCEFILE() - 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_SET() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SHOW() - 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_STORED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STRING() - 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_TEMPORARY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TERMINATED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TEXTFILE() - 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_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_UNDO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNLOCK() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNSIGNED() - 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_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_WITH() - 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.ql.parse.HiveLexer
 
mLESSTHANOREQUALTO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLetter() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLPAREN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mLSQUARE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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.ql.parse.HiveLexer
 
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
 
moduloNum - Variable in class org.apache.hadoop.hive.ql.metadata.Sample
 
MOrder - Class in org.apache.hadoop.hive.metastore.model
 
MOrder(String, int) - Constructor for class org.apache.hadoop.hive.metastore.model.MOrder
 
MoveTask - Class in org.apache.hadoop.hive.ql.exec
MoveTask implementation
MoveTask() - Constructor for class org.apache.hadoop.hive.ql.exec.MoveTask
 
moveToCurrentRow() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
moveToInsertRow() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
moveWork - Class in org.apache.hadoop.hive.ql.plan
 
moveWork() - Constructor for class org.apache.hadoop.hive.ql.plan.moveWork
 
moveWork(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
 
mPLUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mQUESTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mRCURLY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mRegexComponent() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mRPAREN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mRSQUARE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MRU - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
MRU - Most Recently Used cache policy.
MRU(int) - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Construct an MRU with a given maximum number of objects.
MsckDesc - Class in org.apache.hadoop.hive.ql.plan
 
MsckDesc(String, List<Map<String, String>>, Path) - 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
 
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(List<MFieldSchema>, String, String, String, boolean, int, MSerDeInfo, List<String>, List<MOrder>, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
mStringLiteral() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mStringString - Variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
MSTRINGSTRING - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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>) - Constructor for class org.apache.hadoop.hive.metastore.model.MTable
 
mTILDE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.EnumDelegate
 
mWS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
myHashCode - Variable in class org.apache.hadoop.hive.ql.io.HiveKey
 
myInt - Variable in class org.apache.hadoop.hive.serde2.objectinspector.MyStruct
 
myint - Variable in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
MYINT - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
myInteger - Variable in class org.apache.hadoop.hive.serde2.objectinspector.MyStruct
 
myListString - Variable in class org.apache.hadoop.hive.serde2.objectinspector.MyStruct
 
myMapStringString - Variable in class org.apache.hadoop.hive.serde2.objectinspector.MyStruct
 
myString - Variable in class org.apache.hadoop.hive.serde2.objectinspector.MyStruct
 
myString - Variable in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
MYSTRING - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
MyStruct - Class in org.apache.hadoop.hive.serde2.objectinspector
Class for testing TestReflectionObjectInspector.
MyStruct() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.MyStruct
 
myStruct - Variable in class org.apache.hadoop.hive.serde2.objectinspector.MyStruct
 
MyTestClass - Class in org.apache.hadoop.hive.serde2.binarysortable
 
MyTestClass() - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.MyTestClass
 
MyTestClass(Byte, Short, Integer, Long, Float, Double, String, MyTestInnerStruct, List<Integer>) - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.MyTestClass
 
MyTestClassBigger - Class in org.apache.hadoop.hive.serde2.lazybinary
 
MyTestClassBigger() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.MyTestClassBigger
 
MyTestClassBigger(Byte, Short, Integer, Long, Float, Double, String, MyTestInnerStruct, List<Integer>, Map<String, List<MyTestInnerStruct>>) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.MyTestClassBigger
 
MyTestClassSmaller - Class in org.apache.hadoop.hive.serde2.lazybinary
 
MyTestClassSmaller() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.MyTestClassSmaller
 
MyTestClassSmaller(Byte, Short, Integer, Long, Float, Double, String, MyTestInnerStruct) - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.MyTestClassSmaller
 
MyTestInnerStruct - Class in org.apache.hadoop.hive.serde2.binarysortable
 
MyTestInnerStruct() - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.MyTestInnerStruct
 
MyTestInnerStruct(Integer, Integer) - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.MyTestInnerStruct
 

N

NAME - Static variable in class org.apache.hadoop.hive.metastore.api.Database
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
NAME - Static variable in class org.apache.hadoop.hive.metastore.api.Type
 
name - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
NAME_DIRECTORY_ROOT - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Reserved slot for name directory.
NAME_DIRECTORY_ROOT - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Reserved slot for name directory.
Namespace() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
nativeSQL(String) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
NEW_PART - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
NEW_PART - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
NEW_TBL - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
newAggregations() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
newInstance(Class<? extends GenericUDF>, List<exprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
Create a exprNodeGenericFuncDesc based on the genericUDFClass and the children parameters.
newKeys - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
newLineCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
newToken(int) - Static method in class org.apache.hadoop.hive.serde2.dynamic_type.Token
Returns a new Token object, by default.
next() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
Moves the cursor down one row from its current position.
next(Void, FlatFileInputFormat.RowContainer<R>) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
Returns the next row # and value
next(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
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() - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.FastIterator
Returns the next element in the interation.
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.
nextColumnsBatch() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Read in next key buffer and throw any data in current key buffer and current value buffer.
nextKeyBuffer() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
NLISTS - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Number of lists in a file
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
nonNullByte - Variable in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
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.
noOuterJoin - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
noOuterJoin - Variable in class org.apache.hadoop.hive.ql.plan.joinDesc
 
NORMAL_CACHE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Use normal (strong) object references for the record cache.
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.
NOTEQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
NOTEQUAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
notestExecute() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
NSTR - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
nullByte - Variable in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
nullCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
nullPlusNonNullIsNull() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
nullsAreSortedAtEnd() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
nullsAreSortedAtStart() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
nullsAreSortedHigh() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
nullsAreSortedLow() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
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
 
nullText - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The nullString in UTF-8 bytes
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
 
NUMBUCKETS - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
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.
NUMROWS - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 

O

o - Variable in class org.apache.hadoop.hive.serde2.objectinspector.InspectableObject
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
O1 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
O2 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
O3 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
O3 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
O3 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
O3 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
O3 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
O3 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
O3 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
O4 - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
obj - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
obj - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
ObjectBAComparator - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Comparator for objects which have been serialized into byte arrays.
ObjectBAComparator(Comparator) - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.ObjectBAComparator
Construct an ObjectByteArrayComparator which wraps an Object Comparator.
objectClass - Variable in class org.apache.hadoop.hive.serde2.TypedSerDe
 
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
 
ObjectInspectorConverters - Class in org.apache.hadoop.hive.serde2.objectinspector
 
ObjectInspectorConverters() - Constructor for class 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.
ObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
ObjectInspectorFactory() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
ObjectInspectorFactory.ObjectInspectorOptions - Enum in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorOptions describes what ObjectInspector to use.
objectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
ObjectInspectorUtils - Class in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
ObjectInspectorUtils() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
ObjectInspectorUtils.ObjectInspectorCopyOption - Enum in org.apache.hadoop.hive.serde2.objectinspector
This enum controls how we copy primitive objects.
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
 
objectType - Variable in class org.apache.hadoop.hive.serde2.TypedSerDe
 
oi - Variable in class org.apache.hadoop.hive.serde2.objectinspector.InspectableObject
 
onlyContainsPartitionCols() - Method in class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
 
opClass - Variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory.opTuple
 
openNodeScope(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
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
Operator<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
Base operator implementation
Operator() - Constructor for class org.apache.hadoop.hive.ql.exec.Operator
 
Operator(Reporter) - Constructor for class org.apache.hadoop.hive.ql.exec.Operator
Create an operator with a reporter.
Operator.OperatorFunc - Interface in org.apache.hadoop.hive.ql.exec
 
Operator.State - Enum in org.apache.hadoop.hive.ql.exec
 
OperatorFactory - Class in org.apache.hadoop.hive.ql.exec
 
OperatorFactory() - Constructor for class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
OperatorFactory.opTuple<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
 
OperatorFactory.opTuple(Class<T>, Class<? extends Operator<T>>) - Constructor for class org.apache.hadoop.hive.ql.exec.OperatorFactory.opTuple
 
OpParseContext - Class in org.apache.hadoop.hive.ql.parse
Implementation of the Operator Parse Context.
OpParseContext() - Constructor for class org.apache.hadoop.hive.ql.parse.OpParseContext
 
OpParseContext(RowResolver) - Constructor for class org.apache.hadoop.hive.ql.parse.OpParseContext
 
OpProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.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() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory
 
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() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
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.DefaultPPR - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Default processor which just merges its children
OpProcFactory.DefaultPPR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory.DefaultPPR
 
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.JoinPPD - Class in org.apache.hadoop.hive.ql.ppd
Determines predicates for which alias can be pushed to it's parents.
OpProcFactory.JoinPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.JoinPPD
 
OpProcFactory.ReduceSinkPPD - Class in org.apache.hadoop.hive.ql.ppd
Processor for ReduceSink operator.
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.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
 
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
 
optimize() - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
invoke all the transformations one-by-one, and alter the query plan
Optimizer - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of the optimizer
Optimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
OptionsProcessor - Class in org.apache.hadoop.hive.cli
 
OptionsProcessor() - Constructor for class org.apache.hadoop.hive.cli.OptionsProcessor
 
opvec - Static variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory
 
OpWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Context class for operator tree walker for partition pruner.
OpWalkerCtx(HashMap<TableScanOperator, exprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.OpWalkerCtx
Constructor
OpWalkerInfo - Class in org.apache.hadoop.hive.ql.ppd
Context class for operator walker of predicate pushdown.
OpWalkerInfo(HashMap<Operator<? extends Serializable>, OpParseContext>) - Constructor for class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
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 - Static variable in class org.apache.hadoop.hive.metastore.api.Order
 
order - Static variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
orderByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.io - package org.apache.hadoop.hive.common.io
 
org.apache.hadoop.hive.conf - package org.apache.hadoop.hive.conf
 
org.apache.hadoop.hive.hwi - package org.apache.hadoop.hive.hwi
 
org.apache.hadoop.hive.jdbc - package org.apache.hadoop.hive.jdbc
 
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.model - package org.apache.hadoop.hive.metastore.model
 
org.apache.hadoop.hive.ql - package org.apache.hadoop.hive.ql
 
org.apache.hadoop.hive.ql.exec - package org.apache.hadoop.hive.ql.exec
 
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.io - package org.apache.hadoop.hive.ql.io
 
org.apache.hadoop.hive.ql.lib - package org.apache.hadoop.hive.ql.lib
 
org.apache.hadoop.hive.ql.metadata - package org.apache.hadoop.hive.ql.metadata
 
org.apache.hadoop.hive.ql.optimizer - package org.apache.hadoop.hive.ql.optimizer
 
org.apache.hadoop.hive.ql.optimizer.ppr - package org.apache.hadoop.hive.ql.optimizer.ppr
 
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.plan - package org.apache.hadoop.hive.ql.plan
 
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.session - package org.apache.hadoop.hive.ql.session
 
org.apache.hadoop.hive.ql.tools - package org.apache.hadoop.hive.ql.tools
 
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
 
org.apache.hadoop.hive.ql.util.jdbm - package org.apache.hadoop.hive.ql.util.jdbm
 
org.apache.hadoop.hive.ql.util.jdbm.helper - package org.apache.hadoop.hive.ql.util.jdbm.helper
 
org.apache.hadoop.hive.ql.util.jdbm.htree - package org.apache.hadoop.hive.ql.util.jdbm.htree
 
org.apache.hadoop.hive.ql.util.jdbm.recman - package org.apache.hadoop.hive.ql.util.jdbm.recman
 
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.binarysortable - package org.apache.hadoop.hive.serde2.binarysortable
 
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.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.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.objectinspector - package org.apache.hadoop.hive.serde2.lazybinary.objectinspector
 
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.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.thrift_test - package org.apache.hadoop.hive.serde2.thrift_test
 
org.apache.hadoop.hive.serde2.typeinfo - package org.apache.hadoop.hive.serde2.typeinfo
 
org.apache.hadoop.hive.service - package org.apache.hadoop.hive.service
 
org.apache.hadoop.hive.shims - package org.apache.hadoop.hive.shims
 
origProp - Variable in class org.apache.hadoop.hive.conf.HiveConf
 
othersDeletesAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
othersInsertsAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
othersUpdatesAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
out - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
out - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Streams to read/write from
outPath - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
outProtocol - Variable in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
outputAST(String, PrintStream, int) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
OutputByteBuffer - Class in org.apache.hadoop.hive.serde2.binarysortable
This class is much more efficient than ByteArrayOutputStream because none of the methods are synchronized.
OutputByteBuffer() - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.OutputByteBuffer
 
outputColumnNames - Variable in class org.apache.hadoop.hive.ql.plan.joinDesc
 
outputDependencies(PrintStream, List<Task<? extends Serializable>>, int) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
outputDirectory - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
OUTPUTFORMAT - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
outputObjInspector - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
outputStagePlans(PrintStream, List<Task<? extends Serializable>>, int) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
outTransport - Variable in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
outWriter - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
ownDeletesAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
OWNER - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
ownInsertsAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
ownUpdatesAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 

P

PageHeader - Class in org.apache.hadoop.hive.ql.util.jdbm.recman
This class represents a page header.
PageHeader(BlockIo) - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.recman.PageHeader
Constructs a PageHeader object from a block
PARAMETERS - Static variable in class org.apache.hadoop.hive.metastore.api.Partition
 
PARAMETERS - Static variable in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
PARAMETERS - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
PARAMETERS - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
paranoiaMagicOk() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.PageHeader
For paranoia mode
parent - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
parentOperators - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
parentTasks - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
parse(String) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver
 
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.
ParseContext - Class in org.apache.hadoop.hive.ql.parse
Parse Context: The current parse context.
ParseContext() - Constructor for class org.apache.hadoop.hive.ql.parse.ParseContext
 
ParseContext(HiveConf, QB, ASTNode, HashMap<String, ASTPartitionPruner>, HashMap<TableScanOperator, exprNodeDesc>, HashMap<String, SamplePruner>, HashMap<String, Operator<? extends Serializable>>, HashMap<String, Operator<? extends Serializable>>, LinkedHashMap<Operator<? extends Serializable>, OpParseContext>, Map<JoinOperator, QBJoinTree>, HashMap<TableScanOperator, Table>, List<loadTableDesc>, List<loadFileDesc>, Context, HashMap<String, String>, int, UnionProcContext, List<MapJoinOperator>) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseContext
 
ParseDriver - Class in org.apache.hadoop.hive.ql.parse
 
ParseDriver() - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver
 
ParseDriver.ANTLRNoCaseStringStream - Class in org.apache.hadoop.hive.ql.parse
 
ParseDriver.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver.ANTLRNoCaseStringStream
 
ParseDriver.HiveLexerX - Class in org.apache.hadoop.hive.ql.parse
 
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
 
ParseDriver.HiveParserX - Class in org.apache.hadoop.hive.ql.parse
 
ParseDriver.HiveParserX(TokenStream) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveParserX
 
ParseError - Class in org.apache.hadoop.hive.ql.parse
 
ParseException - Exception in org.apache.hadoop.hive.ql.parse
 
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
 
parseHiveHistory(String, HiveHistory.Listener) - Static method in class org.apache.hadoop.hive.ql.history.HiveHistory
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.
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.
parser - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
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.
ParseUtils - Class in org.apache.hadoop.hive.ql.parse
Library of utility functions used in the parse code
ParseUtils() - Constructor for class org.apache.hadoop.hive.ql.parse.ParseUtils
 
PART_VALS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
PART_VALS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
PART_VALS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
partHandle - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
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(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.
partitionDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
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).
PARTITIONKEYS - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
partitionLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
partitionSpec() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionVal() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PARTNAME - Static variable in class org.apache.hadoop.hive.metastore.api.Index
 
partSpec - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
partTypeExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
pathid - Variable in class org.apache.hadoop.hive.ql.Context
 
PATTERN - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
peekNode() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.ColumnPruner
 
PlanUtils - Class in org.apache.hadoop.hive.ql.plan
 
PlanUtils() - Constructor for class org.apache.hadoop.hive.ql.plan.PlanUtils
 
PlanUtils.ExpressionTypes - Enum in org.apache.hadoop.hive.ql.plan
 
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
popNode() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
popObj() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator.IntermediateObject
 
populateJoinKeyValue(Map<Byte, List<ExprNodeEvaluator>>, Map<Byte, List<exprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
postHook(Set<String>, String) - Method in interface org.apache.hadoop.hive.ql.session.SessionState.ResourceHook
 
precedenceAmpersandExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceAmpersandOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceAndExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceAndOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceBitwiseOrExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceBitwiseOrOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceBitwiseXorExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceBitwiseXorOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceEqualExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceEqualOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceFieldExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceNotExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceNotOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceOrExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceOrOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedencePlusExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedencePlusOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceStarExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceStarOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceUnaryOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceUnaryPrefixExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
precedenceUnarySuffixExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PredicatePushDown - Class in org.apache.hadoop.hive.ql.ppd
Implements predicate pushdown.
PredicatePushDown() - Constructor for class org.apache.hadoop.hive.ql.ppd.PredicatePushDown
 
PreExecute - Interface in org.apache.hadoop.hive.ql.hooks
The pre execute hook interface.
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.
preHook(Set<String>, String) - Method in interface org.apache.hadoop.hive.ql.session.SessionState.ResourceHook
 
preorderMap(Operator.OperatorFunc) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
PreOrderWalker - Class in org.apache.hadoop.hive.ql.lib
base class for operator graph walker this class takes list of starting ops and walks them one by one.
PreOrderWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.lib.PreOrderWalker
Constructor
prepareCall(String) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prepareCall(String, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prepareCall(String, int, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prepareStatement(String) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prepareStatement(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prepareStatement(String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prepareStatement(String, String[]) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prepareStatement(String, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prepareStatement(String, int, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
prependPathComponent(String) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator.PathFinder
Appends the specified component to the path list
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.hadoop.hive.jdbc.HiveResultSet
 
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
primitiveCategory - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
The category of the PrimitiveType.
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.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() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter
 
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.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.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.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
 
PrimitiveObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
PrimitiveObjectInspectorFactory is the primary way to create new PrimitiveObjectInspector instances.
PrimitiveObjectInspectorFactory() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
PrimitiveObjectInspectorUtils - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
PrimitiveObjectInspectorUtils() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
PrimitiveObjectInspectorUtils.PrimitiveTypeEntry - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
TypeEntry stores information about a Hive Primitive TypeInfo.
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.
PrimitiveTypes - Static variable in class org.apache.hadoop.hive.serde.Constants
 
primitiveWritableClass - Variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
writableClass refers to hadoop Writable classes like IntWritable, DoubleWritable, Text etc.
print(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
print(String) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
printError(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
printError(String, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
printInfo(String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
printInfo(String, String) - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
PrintOpTreeProcessor - Class in org.apache.hadoop.hive.ql.parse
 
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 class org.apache.hadoop.hive.ql.history.HiveHistory
 
printStackTrace(Exception) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
printStackTrace Helper function to print an exception stack trace to the log and not stderr
printStackTrace() - Method in exception org.apache.hadoop.hive.ql.util.jdbm.helper.WrappedRuntimeException
 
printStackTrace(PrintStream) - Method in exception org.apache.hadoop.hive.ql.util.jdbm.helper.WrappedRuntimeException
 
printStackTrace(PrintWriter) - Method in exception org.apache.hadoop.hive.ql.util.jdbm.helper.WrappedRuntimeException
 
printUsage(String) - Method in class org.apache.hadoop.hive.cli.OptionsProcessor
 
process(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor
 
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.ExtractOperator
 
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.JoinOperator
 
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.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, 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.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.TableScanOperator
Currently, 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.UnionOperator
 
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.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.ColumnPrunerMapJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerReduceSinkProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerSelectProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerTableScanProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.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 Scan 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.GenMRRedSink4
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.MapJoinFactory.MapJoin
Create a task by splitting the plan below the join.
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.MapJoinMapJoin
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.ReduceSinkMapJoin
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.TableScanMapJoin
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory.UnionMapJoin
 
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.ppr.ExprProcFactory.ColumnExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.FieldExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.FuncExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.GenericFuncExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory.DefaultPPR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory.FilterPPR
 
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.UnknownUnion
 
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.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.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.NullExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.NumExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.StrExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.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.FuncExprProcessor
 
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.JoinPPD
 
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.tools.LineageInfo
Implements the process method for the NodeProcessor interface.
process(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.Processor
 
process_stage1(String[]) - Method in class org.apache.hadoop.hive.cli.OptionsProcessor
 
process_stage2(CliSessionState) - Method in class org.apache.hadoop.hive.cli.OptionsProcessor
 
processCmd(String) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processGByExpr(Node, Object) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Function to do groupby subexpression elimination.
processLine(String) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processReader(BufferedReader) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
progressTask(String, Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Called at the end of a task.
prompt - Static variable in class org.apache.hadoop.hive.cli.CliDriver
 
prompt2 - Static variable in class org.apache.hadoop.hive.cli.CliDriver
 
PROPERTIES - Static variable in class org.apache.hadoop.hive.metastore.api.Schema
 
propertiesList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
property - Variable in class org.apache.hadoop.hive.ant.GetVersionPref
The name of the property that gets the version prefix.
Provider - Class in org.apache.hadoop.hive.ql.util.jdbm.recman
Provider of the default RecordManager implementation.
Provider() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.recman.Provider
 
PROVIDER_FACTORY - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Option to create a thread-safe record manager.
prune(Table, exprNodeDesc, HiveConf, String) - 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() - Method in class org.apache.hadoop.hive.ql.parse.ASTPartitionPruner
From the table metadata prune the partitions to return the partitions.
prune(Partition) - Method in class org.apache.hadoop.hive.ql.parse.SamplePruner
Prunes to get all the files in the partition that satisfy the TABLESAMPLE clause
PrunedPartitionList - Class in org.apache.hadoop.hive.ql.parse
The list of pruned partitions.
PrunedPartitionList(Set<Partition>, Set<Partition>, Set<Partition>) - Constructor for class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
 
purgeEntry() - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Purge least recently used object from the cache
pushNode(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
pushObj(ArrayList<Object>) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator.IntermediateObject
 
put(String, String, ColumnInfo) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
put(Operator<? extends Serializable>, OpParseContext) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
put(Object, Object) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.CachePolicy
Place an object in the cache.
put(Object, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Place an object in the cache.
put(Object, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Adds the specified value to the cache under the specified key.
put(Object, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.htree.HTree
Associates the specified value with the specified key.
putOpInsertMap(Operator<T>, RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
putPrunedPreds(Operator<? extends Serializable>, ExprWalkerInfo) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
putToMStringString(String, String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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.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
 
putToProperties(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
putToSuccess(String, Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 

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
 
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
 
QTestGenTask - Class in org.apache.hadoop.hive.ant
 
QTestGenTask() - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask
 
QTestGenTask.QFileFilter - Class in org.apache.hadoop.hive.ant
 
QTestGenTask.QFileFilter() - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask.QFileFilter
 
QUERY - Static variable in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
queryDirectory - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
queryFile - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
queryOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
QueryPlan - Class in org.apache.hadoop.hive.ql
 
QueryPlan(String, BaseSemanticAnalyzer) - Constructor for class org.apache.hadoop.hive.ql.QueryPlan
 
queryStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
queryStatementExpression() - 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
 
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.Constants
 

R

randGen - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
RandomDimension - Class in org.apache.hadoop.hive.ql.metadata
A random dimension is an abstract dimension.
RandomDimension(Class, String) - Constructor for class org.apache.hadoop.hive.ql.metadata.RandomDimension
 
randomid - Variable in class org.apache.hadoop.hive.ql.Context
 
RawStore - Interface in org.apache.hadoop.hive.metastore
 
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 - 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.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.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.
RCFileInputFormat<K extends org.apache.hadoop.io.LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hadoop.hive.ql.io
 
RCFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.RCFileInputFormat
 
RCFileOutputFormat - Class in org.apache.hadoop.hive.ql.io
 
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(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
RCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RCURLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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 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.MetaException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
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.Schema
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.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_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.append_partition_args
 
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.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_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_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.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_partition_args
 
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_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_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.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_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_partition_args
 
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_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_partitions_args
 
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_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_table_args
 
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_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.Type
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
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.serde.test.InnerStruct
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
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.service.HiveClusterStatus
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
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.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_COLUMN_IDS_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
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.serde2.thrift.TBinarySortableProtocol
 
readBool() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readBoolean() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a boolean from this stream.
readByte() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads an 8-bit byte value from this stream.
readByte(int) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Reads a byte from the indicated position
readByte() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readByte() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
readChar() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
 
readChar() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
readColumn(DataInput, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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.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(Table) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
Constructor.
ReadEntity(Partition) - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
Constructor given a partiton.
ReadEntity.Type - Enum in org.apache.hadoop.hive.ql.hooks
Enum that tells what time of a read entity this is.
readExternal(ObjectInput) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
readExternal(ObjectInput) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
readExternal(ObjectInput) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
 
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.ql.exec.ByteWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
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.ByteWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
readFloat() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Reads a 32-bit float value from this stream.
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.
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.ql.io.NonSyncDataInputBuffer
Reads a 32-bit integer value from this stream.
readInt(int) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Reads an int from the indicated position
readIsNull() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readLine() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Deprecated. Use BufferedReader
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.ql.io.NonSyncDataInputBuffer
Reads a 64-bit long value from this stream.
readLong(int) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Reads a long from the indicated position
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
 
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
 
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.ql.io.NonSyncDataInputBuffer
Reads a 16-bit short value from this stream.
readShort(int) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Reads a short from the indicated position
readString() - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
readString() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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
 
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.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.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.
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.
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.
realFile(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Shamelessly cloned from GenericOptionsParser
RECORD_INTERVAL_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
RecordCache - Interface in org.apache.hadoop.hive.ql.util.jdbm.recman
This interface is used for synchronization.
RecordFile - Class in org.apache.hadoop.hive.ql.util.jdbm.recman
This class represents a random access file as a set of fixed size records.
RecordManager - Interface in org.apache.hadoop.hive.ql.util.jdbm
An interface to manages records, which are uninterpreted blobs of data.
RecordManagerFactory - Class in org.apache.hadoop.hive.ql.util.jdbm
This is the factory class to use for instantiating RecordManager instances.
RecordManagerFactory() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerFactory
 
RecordManagerOptions - Class in org.apache.hadoop.hive.ql.util.jdbm
Standard options for RecordManager.
RecordManagerOptions() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
 
RecordManagerProvider - Interface in org.apache.hadoop.hive.ql.util.jdbm
Provider of RecordManager implementation.
recoverFromMismatchedSet(IntStream, RecognitionException, BitSet) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveParserX
 
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_add_partition() - 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_table() - 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_create_database() - 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_type() - 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_partition() - 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_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_execute() - Method in class org.apache.hadoop.hive.service.ThriftHive.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_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_fields() - 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_names() - 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_schema() - 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_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_getClusterStatus() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_getSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
recv_getThriftSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.ExecReducer
 
reduceSinkDesc - Class in org.apache.hadoop.hive.ql.plan
 
reduceSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
reduceSinkDesc(ArrayList<exprNodeDesc>, ArrayList<exprNodeDesc>, ArrayList<String>, ArrayList<String>, int, ArrayList<exprNodeDesc>, int, tableDesc, tableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
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
 
REDUCETASKS - Static variable in class org.apache.hadoop.hive.service.HiveClusterStatus
 
ReflectionStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
ReflectionStructObjectInspector works on struct data that is stored as a native Java object.
ReflectionStructObjectInspector(Class<?>, List<ObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
ReflectionStructObjectInspector.MyField - Class in org.apache.hadoop.hive.serde2.objectinspector
 
ReflectionStructObjectInspector.MyField(Field, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
refreshRow() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
registerCoreSerDes() - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
registerGenericUDAF(boolean, String, GenericUDAFResolver) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerGenericUDF(boolean, String, Class<? extends GenericUDF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerInputFormatChecker(Class<? extends InputFormat>, Class<? extends InputFormatChecker>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
register an InputFormatChecker for a given InputFormat
registerJar(String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
registerOutParameter(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
registerOutParameter(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
registerOutParameter(int, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
registerOutParameter(int, int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
registerOutParameter(String, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
registerOutParameter(String, int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
registerOutputFormatSubstitute(Class<? extends OutputFormat>, Class<? extends HiveOutputFormat>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
register a substitute
registerSerDe(String, Class<?>) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
registerTemporaryGenericUDAF(String, GenericUDAFResolver) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerTemporaryGenericUDF(String, Class<? extends GenericUDF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerTemporaryUDAF(String, Class<? extends UDAF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerTemporaryUDF(String, Class<? extends UDF>, FunctionInfo.OperatorType, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDAF(boolean, String, Class<? extends UDAF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDF(boolean, String, Class<? extends UDF>, FunctionInfo.OperatorType, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDF(String, Class<? extends UDF>, FunctionInfo.OperatorType, boolean, String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
regular_body() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.
reinitSerDe() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
relative(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
releaseSavepoint(Savepoint) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
remove(Object) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.CachePolicy
Remove the object stored under the key specified.
remove(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Remove an object from the cache
remove(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Removes any object stored under the key specified.
remove(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.htree.HTree
Remove the value which is associated with the given key.
removeAll() - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.CachePolicy
Remove all objects from the cache.
removeAll() - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Remove all objects from the cache
removeAll() - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Removes all objects in this (L2) and its internal (L1) cache.
removeChild(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
removeDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
remove the dependent task
removeEntry(CacheEntry) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Remove a CacheEntry from linked list
removeFromClassPath(String[]) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
remove elements from the classpath
removeListener(CachePolicyListener) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.CachePolicy
Remove a listener from this cache policy.
removeListener(CachePolicyListener) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Remove a listener from this cache policy
removeListener(CachePolicyListener) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Removes a listener that was added earlier.
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.
rename(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Rename src to dst, or in the case dst already exists, move files in src to dst.
renameOrMoveFiles(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Rename src to dst, or in the case dst already exists, move files in src to dst.
replaceChild(Operator<? extends Serializable>, Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Replace one child with another at the same position.
replaceFiles(Path, Path, FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
Replaces files in the partition with new data set specifed by srcf.
replaceFiles(Path, Path) - Method in class org.apache.hadoop.hive.ql.metadata.Table
Replaces files in the partition with new data set specified by srcf.
replaceParent(Operator<? extends Serializable>, Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Replace one parent with another at the same position.
reporter - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
requiredness - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
Is this a required, skippable or optional field.
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(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() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
reset() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluator
 
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.GenericUDAFCount.GenericUDAFCountEvaluator
 
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.GenericUDAFSum.GenericUDAFSumDouble
 
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(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Reset the byte buffer to the given byte range.
reset() - Method in class org.apache.hadoop.hive.serde2.binarysortable.OutputByteBuffer
Reset the byte buffer.
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
 
resetAggregations(GenericUDAFEvaluator.AggregationBuffer[]) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
resetId() - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
resetStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
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.
resultsDirectory - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
RETENTION - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
retrieve(InspectableObject) - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
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.
reverseLookup(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
RIGHT_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.joinDesc
 
rollback() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
rollback(Savepoint) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
rollback() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Rollback (cancel) all changes since beginning of transaction.
rollback() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Rollback (cancel) all changes since beginning of transaction.
rollback() - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Rollback (cancel) all changes since beginning of transaction.
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
rootNode() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
rootTasks - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
rowCountMap - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
rowDeleted() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
rowInserted() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
rowList - Variable in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
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
 
RowSchema - Class in org.apache.hadoop.hive.ql.exec
RowSchema Implementation
RowSchema() - Constructor for class org.apache.hadoop.hive.ql.exec.RowSchema
 
RowSchema(Vector<ColumnInfo>) - Constructor for class org.apache.hadoop.hive.ql.exec.RowSchema
 
rowSeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
rowUpdated() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
RPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RPAREN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RSQUARE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Rule - Interface in org.apache.hadoop.hive.ql.lib
Rule interface for Operators Used in operator dispatching to dispatch process/visitor functions for operators
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() - 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(String) - Method in class org.apache.hadoop.hive.ql.Driver
 
run() - Method in class org.apache.hadoop.hive.ql.exec.Utilities.StreamPrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in interface org.apache.hadoop.hive.ql.hooks.PreExecute
The run command that is called just before the execution of the query.
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.DeleteResourceProcessor
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
RUNNING - Static variable in class org.apache.hadoop.hive.service.JobTrackerState
 
runningJobKillURIs - Static variable in class org.apache.hadoop.hive.ql.exec.ExecDriver
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.
runQuery() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This method calls the qp.run() method, writes the output to the result file, when finished the status will be QUERY_COMPLETE.
runSetProcessorQuery(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Set processor queries block for only a short amount of time.

S

Sample - Class in org.apache.hadoop.hive.ql.metadata
A sample defines a subset of data based on sampling on a given dimension
Sample(int, int, Dimension) - Constructor for class org.apache.hadoop.hive.ql.metadata.Sample
 
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.parse
This class stores the mapping from table alias to the parse tree information of the table sample clause(stored in the TableSample class).
SamplePruner() - Constructor for class org.apache.hadoop.hive.ql.parse.SamplePruner
 
SamplePruner(String, TableSample) - Constructor for class org.apache.hadoop.hive.ql.parse.SamplePruner
Constructs the SamplePruner given the table alias and the table sample
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.
schemaDesc - Class in org.apache.hadoop.hive.ql.plan
 
schemaDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.schemaDesc
 
schemaDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.schemaDesc
 
scriptDesc - Class in org.apache.hadoop.hive.ql.plan
 
scriptDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.scriptDesc
 
scriptDesc(String, tableDesc, tableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.scriptDesc
 
ScriptOperator - Class in org.apache.hadoop.hive.ql.exec
 
ScriptOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
ScriptOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
 
ScriptOperator.PathFinder - Class in org.apache.hadoop.hive.ql.exec
Maps a relative pathname to an absolute pathname using the PATH enviroment.
ScriptOperator.PathFinder(String) - Constructor for class org.apache.hadoop.hive.ql.exec.ScriptOperator.PathFinder
Construct a PathFinder object using the path from the specified system environment variable.
SD - Static variable in class org.apache.hadoop.hive.metastore.api.Partition
 
SD - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
searchCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
secondaryPattern - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
secondarySeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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(int) - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Set the current position.
selectClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectDesc - Class in org.apache.hadoop.hive.ql.plan
 
selectDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.selectDesc
 
selectDesc(boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.selectDesc
 
selectDesc(ArrayList<exprNodeDesc>, ArrayList<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.selectDesc
 
selectDesc(ArrayList<exprNodeDesc>, ArrayList<String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.selectDesc
 
selectDesc(ArrayList<exprNodeDesc>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.selectDesc
 
selectExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectExpressionList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectItem() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SelectOperator - Class in org.apache.hadoop.hive.ql.exec
Select operator implementation
SelectOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.SelectOperator
 
SemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
Implementation of the semantic analyzer
SemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
SemanticAnalyzerFactory - Class in org.apache.hadoop.hive.ql.parse
 
SemanticAnalyzerFactory() - Constructor for class 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
 
SEMICOLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
SEMICOLON - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
send_add_partition(Partition) - 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_table(String, String, Table) - 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_create_database(String, String) - 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_type(Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_database(String) - 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_table(String, String, boolean) - 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_execute(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.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_get_database(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_databases() - 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_partition(String, String, List<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_partitions(String, String, short) - 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_table(String, String) - 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_getClusterStatus() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_getSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
send_getThriftSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.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
 
SequenceFileInputFormatChecker - Class in org.apache.hadoop.hive.ql.io
 
SequenceFileInputFormatChecker() - Constructor for class org.apache.hadoop.hive.ql.io.SequenceFileInputFormatChecker
 
serde() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SerDe - Interface in org.apache.hadoop.hive.serde2
A union of HiveDeserializer and HiveSerializer interface.
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
 
serdeFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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 - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
serdePropertiesFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SerDeUtils - Class in org.apache.hadoop.hive.serde2
 
SerDeUtils() - Constructor for class org.apache.hadoop.hive.serde2.SerDeUtils
 
Serialization - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Serialization-related utility methods.
Serialization() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.Serialization
 
SERIALIZATION_CLASS - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SERIALIZATION_DDL - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SERIALIZATION_FORMAT - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SERIALIZATION_LAST_COLUMN_TAKES_REST - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SERIALIZATION_LIB - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SERIALIZATION_NULL_FORMAT - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SERIALIZATION_SORT_ORDER - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SerializationContextImplKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
The JobConf key of the SerializationContext to use
SerializationImplKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
The JobConf keys for the Serialization implementation
SERIALIZATIONLIB - Static variable in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
SerializationSubclassKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
The JobConf keys for the Class that is being deserialized.
serialize(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.ByteArraySerializer
Serialize the content of an object into a byte array.
serialize(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.DefaultSerializer
Serialize the content of an object into a byte array.
serialize(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.IntegerSerializer
Serialize the content of an object into a byte array.
serialize(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.LongSerializer
Serialize the content of an object into a byte array.
serialize(Object) - Static method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Serialization
Serialize the object into a byte array.
serialize(Object) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.helper.Serializer
Serialize the content of an object into a byte array.
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.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(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
Serialize a row of data.
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(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
serialize(Object, ObjectInspector) - Method in interface org.apache.hadoop.hive.serde2.Serializer
Serialize an object by navigating inside the Object with the ObjectInspector.
serialize(TBase) - Method in class org.apache.hadoop.hive.serde2.thrift_test.CreateSequenceFile.ThriftSerializer
 
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.TypedSerDe
 
serializeMapRedWork(mapredWork, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Serialize the plan object to an output stream.
serializer - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
Serializer - Interface in org.apache.hadoop.hive.ql.util.jdbm.helper
Interface used to provide a serialization mechanism other than a class' normal serialization.
Serializer - Interface in org.apache.hadoop.hive.serde2
HiveSerializer is used to serialize data to a Hadoop Writable object.
serializeTasks(Task<? extends Serializable>, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
serialVersionUID - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
 
Service() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
sessionId - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.SessionInfo
 
SessionState - Class in org.apache.hadoop.hive.ql.session
SessionState encapsulates common data associated with a session Also provides support for a thread static session object that can be accessed from any point in the code to interact with the user and to retrieve configuration information
SessionState() - Constructor for class org.apache.hadoop.hive.ql.session.SessionState
 
SessionState(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.session.SessionState
 
SessionState(HiveConf, Hive) - Constructor for class org.apache.hadoop.hive.ql.session.SessionState
 
SessionState.LogHelper - Class in org.apache.hadoop.hive.ql.session
This class provides helper routines to emit informational and error messages to the user and log4j files while obeying the current session's verbosity levels.
SessionState.LogHelper(Log) - Constructor for class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
SessionState.LogHelper(Log, boolean) - Constructor for class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
SessionState.ResourceHook - Interface in org.apache.hadoop.hive.ql.session
 
SessionState.ResourceType - Enum in org.apache.hadoop.hive.ql.session
 
set(int) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
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(byte) - Method in class org.apache.hadoop.hive.serde2.io.ByteWritable
 
set(double) - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
set(short) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
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, 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, 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, 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, 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, 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_table_parameters(String, String, Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
setAddPartitionDesc(AddPartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAggregationExprsForClause(String, LinkedHashMap<String, ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setAggregators(ArrayList<aggregationDesc>) - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
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.Operator
Store the alias this operator is working on behalf of
setAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.tableScanDesc
 
setAliasToFetchWork(LinkedHashMap<String, fetchWork>) - Method in class org.apache.hadoop.hive.ql.plan.mapredLocalWork
 
setAliasToPartnInfo(LinkedHashMap<String, partitionDesc>) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
setAliasToPruner(HashMap<String, ASTPartitionPruner>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setAliasToSamplePruner(HashMap<String, SamplePruner>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setAliasToWork(LinkedHashMap<String, Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.mapredLocalWork
 
setAliasToWork(LinkedHashMap<String, Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
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.
setAlterTblDesc(alterTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setArray(int, Array) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setArray(int, Array) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setAsciiStream(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setAsciiStream(String, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setAsciiStream(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setAsciiStream(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setAsciiStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setAsciiStream(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setAsciiStream(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setAsciiStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setAsciiStream(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setAString(String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setAStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setAstStringTree(String) - Method in class org.apache.hadoop.hive.ql.plan.explainWork
 
setAuth(HWIAuth) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setAutoCommit(boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setAuxJars(String) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setBaseSrc(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setBigDecimal(String, BigDecimal) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBigDecimal(int, BigDecimal) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBigDecimal(int, BigDecimal) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setBinaryStream(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBinaryStream(String, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBinaryStream(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBinaryStream(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBinaryStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBinaryStream(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBinaryStream(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setBinaryStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setBinaryStream(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setBlob(String, Blob) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBlob(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBlob(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBlob(int, Blob) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBlob(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBlob(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBlob(int, Blob) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setBlob(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setBlob(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setBoolean(String, boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBoolean(int, boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBoolean(int, boolean) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
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.createTableDesc
 
setBufferSize(Integer) - Method in class org.apache.hadoop.hive.ql.plan.collectDesc
 
setByte(String, byte) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setByte(int, byte) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setByte(int, byte) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setBytes(String, byte[]) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBytes(int, byte[]) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setBytes(int, byte[]) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setCatalog(String) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setCharacterStream(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setCharacterStream(String, Reader, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setCharacterStream(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setCharacterStream(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setCharacterStream(int, Reader, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setCharacterStream(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setCharacterStream(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setCharacterStream(int, Reader, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setCharacterStream(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setCheckFileFormat(boolean) - Method in class org.apache.hadoop.hive.ql.plan.moveWork
 
setChildExprs(List<exprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
setChildExprs(List<exprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
setChildOperators(List<Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setChildren(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
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.ql.plan.createFunctionDesc
 
setClientInfo(Properties) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setClientInfo(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setClob(String, Clob) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setClob(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setClob(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setClob(int, Clob) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setClob(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setClob(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setClob(int, Clob) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setClob(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setClob(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
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.session.SessionState
 
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(exprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.extractDesc
 
setColList(ArrayList<exprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.selectDesc
 
setCollItemDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setColNames(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
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.MStorageDescriptor
 
setCols(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setColumn(String) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
setColumnExprMap(Map<String, exprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setColumnNumber(Configuration, int) - Static method in class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
set number of columns into the given configuration.
setColumns(String) - Method in class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
setColumnTypes(String) - Method in class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
setCommand(String) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
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.createTableDesc
 
setComments(String) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
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
 
setConds(joinCond[]) - Method in class org.apache.hadoop.hive.ql.plan.joinDesc
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
setConf(T) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setConfirmedPartns(Set<Partition>) - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
set confirmed partitions
setContext(Context) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setCreateFunctionDesc(createFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
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.Partition
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setCurrAliasId(String) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrMapJoinOp(MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrMapJoinOp(MapJoinOperator) - 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 Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrUnionOp(UnionOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCursorName(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setCursorName(String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setCursorName(String) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
setData(byte[]) - Method in class org.apache.hadoop.hive.serde2.lazy.ByteArrayRef
 
setDatabase(MDatabase) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setDataLocation(URI) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setDate(String, Date) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setDate(String, Date, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setDate(int, Date) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setDate(int, Date, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setDate(int, Date) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setDate(int, Date, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
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.append_partition_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.get_fields_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_names_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_schema_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.drop_table_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.ql.plan.AddPartitionDesc
 
setDebugStream(PrintStream) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Set debug output.
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_table_args
 
setDenominator(int) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the denominator
setDesc(exprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
setDescFuncDesc(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.api.ThriftHiveMetastore.create_database_args
 
setDescription(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setDescTblDesc(descTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDeserializer(Deserializer) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setDeserializerClass(Class<? extends Deserializer>) - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
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
 
setDestLimit(String, Integer) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setDestTableId(int) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setDestTableId(int) - Method in class org.apache.hadoop.hive.ql.plan.fileSinkDesc
 
setDeterministic(boolean) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
sets the deterministic flag for this expression
setDir(String) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
setDirName(String) - Method in class org.apache.hadoop.hive.ql.plan.fileSinkDesc
 
setDistinct(boolean) - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
setDistinctFuncExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setDistributeByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Set the Distribute By AST for the clause.
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setDone() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setDouble(String, double) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setDouble(int, double) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setDouble(int, double) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setDropFunctionDesc(dropFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
setDropTblDesc(dropTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setError(String) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setErrorFile(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Currently unused
setEscapeProcessing(boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setEscapeProcessing(boolean) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setEscapeProcessing(boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
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.getSchema_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setExplain(boolean) - Method in class org.apache.hadoop.hive.ql.Context
Set the context on whether the current query is an explain query
setExpressions(Vector<Vector<ASTNode>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
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.joinDesc
 
setExt(boolean) - Method in class org.apache.hadoop.hive.ql.plan.descTableDesc
 
setExtended(boolean) - Method in class org.apache.hadoop.hive.ql.plan.descFunctionDesc
 
setExtended(boolean) - Method in class org.apache.hadoop.hive.ql.plan.explainWork
 
setExternal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setExternal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.createTableLikeDesc
 
setFetchDirection(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setFetchDirection(int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setFetchDirection(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
setFetchDirection(int) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
setFetchSize(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setFetchSize(int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setFetchSize(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
setFetchSize(int) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
setFetchTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
setFetchTaskInit(boolean) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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.createTableDesc
 
setFieldEscape(String) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setFieldName(String) - Method in class org.apache.hadoop.hive.ql.plan.explosionDesc
 
setFieldName(String) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
setFields(List<FieldSchema>) - Method in class org.apache.hadoop.hive.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
 
setFieldSchemas(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setFieldValue(int, Object) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
setFieldValue(int, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setFilters(Vector<Vector<ASTNode>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setFloat(String, float) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setFloat(int, float) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setFloat(int, float) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setFromPath(String) - Method in class org.apache.hadoop.hive.ql.plan.copyWork
 
setFullyReadColumns(Configuration) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Clears the read column ids set in the conf, and will read all columns.
setFunctionName(String) - Method in class org.apache.hadoop.hive.ql.plan.createFunctionDesc
 
setFunctionName(String) - Method in class org.apache.hadoop.hive.ql.plan.dropFunctionDesc
 
setGenericUDAFEvaluator(GenericUDAFEvaluator) - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
setGenericUDAFEvaluatorClass(Class<? extends GenericUDAFEvaluator>) - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
setGenericUDAFName(String) - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
setGenericUDFClass(Class<? extends GenericUDF>) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeGenericFuncDesc
 
setGoOn(boolean) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
setGroupByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setGroupKeyNotReductionKey(boolean) - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
setGroups(String[]) - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
setHashCode(int) - Method in class org.apache.hadoop.hive.ql.io.HiveKey
 
setHasNonPartCols(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcCtx
 
setHasNonPartCols(boolean) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
Sets the hasNonPartCols flag
setHints(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setHoldability(int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setId(String) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setId(String) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setIdToTableMap(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Set the table to id map
setIdToTableNameMap(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.createTableLikeDesc
 
setIndexName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexType(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setInput(String) - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
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(String) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
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
 
setInputPruning(boolean) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the flag that indicates whether input pruning is possible or not
setInputRR(RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setInt(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setInt(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setInt(int, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setInternalName(String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setIsCandidate(exprNodeDesc, boolean) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Marks the specified expr to the specified value
setIsDfsDir(boolean) - Method in class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
setIsExprResolver(boolean) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setIsList(Boolean) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
setIsOperator(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
setIsPartitionCol(boolean) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
setIsQuery(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setIsSamplingPred(boolean) - Method in class org.apache.hadoop.hive.ql.plan.filterDesc
 
setIsSilent(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setItems(TreeMap<HWIAuth, Set<HWISessionItem>>) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
setJoinCond(joinCond[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setJoinContext(Map<JoinOperator, QBJoinTree>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setJoinExpr(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setJoinSrc(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setJoinType(joinType) - Method in class org.apache.hadoop.hive.ql.parse.joinCond
 
setKey(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Tuple
Set the key.
setKeyAndValueDesc(mapredWork, Operator<? extends Serializable>) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
set key and value descriptor
setKeyCols(ArrayList<exprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
setKeyDesc(tableDesc) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
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.mapJoinDesc
 
setKeySerializeInfo(tableDesc) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
setKeyTblDesc(tableDesc) - Method in class org.apache.hadoop.hive.ql.plan.mapJoinDesc
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setLeft(int) - Method in class org.apache.hadoop.hive.ql.parse.joinCond
 
setLeft(int) - Method in class org.apache.hadoop.hive.ql.plan.joinCond
 
setLeftAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
set left alias for the join expression
setLeftAliases(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
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
 
setLineDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
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
 
setListElementTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
For java serialization use only.
setListMapJoinOpsNoReducer(List<MapJoinOperator>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setListMapJoins(List<MapJoinOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setListRejectedMapJoins(List<MapJoinOperator>) - 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
 
setListWorks(List<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalWork
 
setLoadFileWork(List<loadFileDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setLoadFileWork(loadFileDesc) - Method in class org.apache.hadoop.hive.ql.plan.moveWork
 
setLoadTableWork(List<loadTableDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setLoadTableWork(loadTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.moveWork
 
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.plan.AddPartitionDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.createTableLikeDesc
 
setLogDirectory(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setLogFile(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setLoginTimeout(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
setLogWriter(PrintWriter) - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
setLong(String, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setLong(int, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setLong(int, long) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setLString(List<String>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setLStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setMapAliases(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setMapCurrCtx(LinkedHashMap<Operator<? extends Serializable>, GenMRProcContext.GenMapRedCtx>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setMapJoinCtx(MapJoinOperator, GenMRProcContext.GenMRMapJoinCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
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.
setMapLocalWork(mapredLocalWork) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
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
 
setMapProp(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setMapRedWork(Configuration, mapredWork) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setMapSideJoin(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setMapTasks(int) - 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.
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_partitions_args
 
setMaxFieldSize(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setMaxFieldSize(int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setMaxFieldSize(int) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
setMaximumTransactionsInLog(int) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.TransactionManager
Set the maximum number of transactions to record in the log (and keep in memory) before the log is synchronized with the main database file.
setMaxMapTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxReduceTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxRows(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setMaxRows(int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setMaxRows(int) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
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
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
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.MetaException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setMetadataTag(int) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
setMetadataTag(int) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
setMethodName(String) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
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
 
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
 
setMvTask(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
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.create_database_args
 
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.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.MSerDeInfo
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.descFunctionDesc
 
setNamedObject(String, long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Set the record id of a named object.
setNamedObject(String, long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Set the record id of a named object.
setNamedObject(String, long) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Set the record id of a named object.
setNCharacterStream(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNCharacterStream(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNCharacterStream(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNCharacterStream(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNCharacterStream(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setNCharacterStream(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setNClob(String, NClob) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNClob(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNClob(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNClob(int, NClob) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNClob(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNClob(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNClob(int, NClob) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setNClob(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setNClob(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setNeededColumnIDs(ArrayList<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
setNeedsTagging(boolean) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
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.alter_partition_args
 
setNew_tbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setNewCols(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
setNewName(String) - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
setNoOuterJoin(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setNoOuterJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.joinDesc
 
setNString(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNString(int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNString(int, String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setNull(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNull(String, int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNull(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNull(int, int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setNull(int, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setNull(int, int, String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setNumberOfReducers() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
Set the number of reducers for the mapred work.
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.plan.createTableDesc
 
setNumerator(int) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the numerator
setNumInputs(int) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
setNumInputs(int) - Method in class org.apache.hadoop.hive.ql.plan.unionDesc
 
setNumReducers(int) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
setNumReduceTasks(Integer) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
setNumRows(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_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_table_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_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_table_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.drop_partition_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.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_fields_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_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_table_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_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_table_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO2(MetaException) - 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_table_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.drop_database_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_type_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(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO2(UnknownTableException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_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_type_all_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_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.append_partition_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_type_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_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_schema_result
 
setO4(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setObj(ArrayList<Object>) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
setObj(ArrayList<ArrayList<Object>>) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
setObject(String, Object) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setObject(String, Object, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setObject(String, Object, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setObject(int, Object) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setObject(int, Object, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setObject(int, Object, int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setObject(int, Object) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setObject(int, Object, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setObject(int, Object, int, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setOldMapJoin(MapJoinOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
setOldName(String) - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
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
 
setOpParseCtx(LinkedHashMap<Operator<? extends Serializable>, OpParseContext>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpTaskMap(HashMap<Operator<? extends Serializable>, 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
 
setOpType(FunctionInfo.OperatorType) - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
setOrder(int) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setOrder(int) - Method in class org.apache.hadoop.hive.metastore.model.MOrder
 
setOrderByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setOuterQueryLimit(int) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setOutputCollector(OutputCollector) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setOutputColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.groupByDesc
 
setOutputColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.joinDesc
 
setOutputColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.selectDesc
 
setOutputDirectory(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
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.createTableDesc
 
setOutputFormatClass(Class<?>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOutputFormatClass(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOutputKeyColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
setOutputValueColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
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
 
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.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.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(ArrayList<exprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.aggregationDesc
 
setParentOperators(List<Operator<? extends Serializable>>) - 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
 
setParseCtx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setParseTree(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
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.drop_partition_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setPartCols(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setPartCols(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setPartDesc(List<partitionDesc>) - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
setPartDir(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
setPartitionCols(ArrayList<exprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
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
 
setPartitionName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
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(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
setPartitionSpec(List<Map<String, String>>) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setPartName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setPartSpec(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.partitionDesc
 
setPartSpecs(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.descTableDesc
 
setPartSpecs(List<Map<String, String>>) - Method in class org.apache.hadoop.hive.ql.plan.dropTableDesc
 
setPathToAliases(LinkedHashMap<String, ArrayList<String>>) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
setPathToPartitionInfo(LinkedHashMap<String, partitionDesc>) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
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.plan.showFunctionsDesc
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.showTablesDesc
 
setPctx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
setPoolable(boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setPoolable(boolean) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setPoolable(boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
setPosBigTable(int) - Method in class org.apache.hadoop.hive.ql.plan.mapJoinDesc
 
setPosition(int) - Method in class org.apache.hadoop.hive.ql.plan.explosionDesc
 
setPosToAliasMap(Map<Integer, Set<String>>) - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
setPredicate(exprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.filterDesc
 
SetProcessor - Class in org.apache.hadoop.hive.ql.processors
 
SetProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.SetProcessor
 
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.tableDesc
 
setProperty(String) - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
setProperty(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.alterTableDesc
 
setQB(QB) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setQB(QB) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setQBExpr1(QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setQBExpr2(QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setQbJoinTree(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setQBParseInfo(QBParseInfo) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setQp(Driver) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setQuery(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Use this function to set the query that Hive will run.
setQuery(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
setQueryDirectory(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setQueryFile(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setQueryProperty(String, HiveHistory.Keys, String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Used to set job status and other attributes of a job
setQueryRet(int) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setQueryTimeout(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setQueryTimeout(int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setQueryTimeout(int) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
setReadColumnIDs(Configuration, ArrayList<Integer>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Sets read columns' ids(start from zero) for RCFile's Reader.
setReadOnly(boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setReducer(Operator<?>) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
setReduceTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setRef(int, Ref) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setRef(int, Ref) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setReplace(boolean) - Method in class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
setReporter(Reporter) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setResDir(Path) - Method in class org.apache.hadoop.hive.ql.Context
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.Context
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.plan.descFunctionDesc
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.plan.descTableDesc
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.plan.explainWork
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.plan.showFunctionsDesc
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.plan.showPartitionsDesc
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.plan.showTablesDesc
 
setResolver(ConditionalResolver) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
setResolver(UDAFEvaluatorResolver) - Method in class org.apache.hadoop.hive.ql.exec.UDAF
Sets the resolver
setResolver(UDFMethodResolver) - Method in class org.apache.hadoop.hive.ql.exec.UDF
Sets the resolver
setResolverCtx(Object) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
setResultFile(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setResultsDirectory(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
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
 
setReversedExprs(Map<String, Byte>) - Method in class org.apache.hadoop.hive.ql.plan.joinDesc
 
setRight(int) - Method in class org.apache.hadoop.hive.ql.parse.joinCond
 
setRight(int) - Method in class org.apache.hadoop.hive.ql.plan.joinCond
 
setRightAliases(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setRoot(int, long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Sets the indicated root rowid.
setRoot(int, long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Sets the indicated root rowid.
setRoot(int, long) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Sets the indicated root rowid.
setRootMapJoinOp(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
setRootOps(List<Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
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.plan.explainWork
 
setRowId(String, RowId) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setRowId(int, RowId) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setRowId(int, RowId) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setRR(RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.OpParseContext
 
setSavepoint() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setSavepoint(String) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setSchema(RowSchema) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setSchema(Properties) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSchema(String) - Method in class org.apache.hadoop.hive.ql.plan.schemaDesc
 
setScriptCmd(String) - 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
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setSd(MStorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setSd(MStorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setSeenFileSinkOps(List<FileSinkOperator>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setSeenOps(List<Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
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
 
setSerdeClassName(String) - Method in class org.apache.hadoop.hive.ql.plan.tableDesc
 
setSerdeInfo(SerDeInfo) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setSerDeInfo(MSerDeInfo) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
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
 
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
 
setSerializationNullFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
setSerName(String) - Method in class org.apache.hadoop.hive.ql.plan.createTableDesc
 
setSessionName(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setShort(String, short) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setShort(int, short) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setShort(int, short) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setShowFuncsDesc(showFunctionsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowPartsDesc(showPartitionsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowTblsDesc(showTablesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setSignature(Vector<ColumnInfo>) - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
setSortByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Set the Sort By AST for the clause.
setSortCols(List<Order>) - Method in class org.apache.hadoop.hive.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.createTableDesc
 
setSourceDir(String) - Method in class org.apache.hadoop.hive.ql.plan.loadDesc
 
setSp(SetProcessor) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setSQLXML(String, SQLXML) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setSQLXML(int, SQLXML) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setSQLXML(int, SQLXML) - Method in class org.apache.hadoop.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
 
setSs(CliSessionState) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setSSIsSilent(boolean) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is a chained call to SessionState.setIsSilent().
setState(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setString(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setString(int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setString(int, String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setSubqAlias(String, QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
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.append_partition_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_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.drop_database_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_type_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(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_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(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setSuccess(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setSuccess(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_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(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(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
 
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.parse.SamplePruner
Sets the table alias
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(tableDesc) - Method in class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
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_schema_args
 
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.
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.
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.
SettableLongObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableLongObjectInspector can set a long value to an object.
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setTableName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
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.dropTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setTableSample(TableSample) - Method in class org.apache.hadoop.hive.ql.parse.SamplePruner
Sets the parse information of the associated table sample clause
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
 
SettableStringObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableStringObjectInspector can set a string value to an object.
setTabName(String) - Method in class org.apache.hadoop.hive.ql.plan.showPartitionsDesc
 
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(int) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
setTagToValueDesc(List<tableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
setTargetDir(String) - Method in class org.apache.hadoop.hive.ql.plan.loadFileDesc
 
setTaskCounters(String, String, RunningJob) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Serialize the task counters and set as a task property.
setTaskPlan(String, Operator<? extends Serializable>, mapredWork, boolean, GenMRProcContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
set the current task in the mapredWork
setTaskPlan(String, String, Operator<? extends Serializable>, mapredWork, 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 class org.apache.hadoop.hive.ql.history.HiveHistory
Used to set task properties.
setTaskTmpDir(String) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
setTaskTrackers(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setTbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
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_table_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.drop_partition_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_names_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_table_args
 
setTblDesc(tableDesc) - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
setTblDir(String) - Method in class org.apache.hadoop.hive.ql.plan.fetchWork
 
setTemplate(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setTemplatePath(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setTime(String, Time) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setTime(String, Time, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setTime(int, Time) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setTime(int, Time, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setTime(int, Time) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setTime(int, Time, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setTimestamp(String, Timestamp) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setTimestamp(String, Timestamp, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setTimestamp(int, Timestamp) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setTimestamp(int, Timestamp) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setTmpDir(String) - Method in class org.apache.hadoop.hive.ql.plan.loadTableDesc
 
setTmpFiles(String, String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
If JobClient.getCommandLineConfig exists, sets the given property/value pair in that Configuration object.
setToPath(String) - Method in class org.apache.hadoop.hive.ql.plan.copyWork
 
setTopOps(HashMap<String, Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setTopSelOps(HashMap<String, Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setTopToTable(HashMap<TableScanOperator, Table>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setTransactionIsolation(int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setTreeAdaptor(TreeAdaptor) - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
setTTable(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setTTDesc(tableDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
setType(String) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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(TypeInfo) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setType(int) - Method in class org.apache.hadoop.hive.ql.plan.joinCond
 
setType1(String) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setType1(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setType2(String) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setType2(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeDesc
 
setTypeMap(Map<String, Class<?>>) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setTypeName(String) - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
 
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
 
setUDFClass(Class<? extends UDF>) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
setUDFMethod(Method) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
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.hadoop.hive.jdbc.HiveCallableStatement
 
setUnicodeStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
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
 
setUnknownPartns(Set<Partition>) - Method in class org.apache.hadoop.hive.ql.parse.PrunedPartitionList
set unknown partitions
setUp() - Method in class org.apache.hadoop.hive.hwi.TestHWIServer
 
setUp() - Method in class org.apache.hadoop.hive.hwi.TestHWISessionManager
 
setUp() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
setUp() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
setUp() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
setURL(String, URL) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setURL(int, URL) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
setURL(int, URL) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
setUseJSONSerialize(boolean) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
setUser(String) - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
setUTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
setValue(Object) - Method in class org.apache.hadoop.hive.ql.plan.exprNodeConstantDesc
 
setValue(Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.Tuple
Set the value.
setValueCols(ArrayList<exprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
setValues(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setValues(List<String>) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setValueSerializeInfo(tableDesc) - Method in class org.apache.hadoop.hive.ql.plan.reduceSinkDesc
 
setValueTblDescs(List<tableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.mapJoinDesc
 
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
 
setVersion(String) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setView(BlockView) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Sets the current view of the block.
setWhrExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setWork(T) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
ShimLoader - Class in org.apache.hadoop.hive.shims
 
ShimLoader() - Constructor for class org.apache.hadoop.hive.shims.ShimLoader
 
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
 
shortWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
 
shortWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
 
shortWritable - Variable in class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
 
ShortWritable - Class in org.apache.hadoop.hive.serde2.io
 
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
 
shouldIgnoreField(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
showFunctionsDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
showPartitionsDesc - Class in org.apache.hadoop.hive.ql.plan
 
showPartitionsDesc(String, Path) - Constructor for class org.apache.hadoop.hive.ql.plan.showPartitionsDesc
 
showStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
showStmtIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
showTablesDesc - Class in org.apache.hadoop.hive.ql.plan
 
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
 
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 interface org.apache.hadoop.hive.shims.HadoopShims.MiniDFSShim
 
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
 
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
 
SIZE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.recman.PageHeader
 
size() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Returns the number of valid elements.
skip(long) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
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.
skipBytes(int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Skips count number of bytes in this stream.
SkippableTProtocol - Interface in org.apache.hadoop.hive.serde2.thrift
An interface for TProtocols that can efficiently skip fields when deserializing.
SMALLINT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SOFT_REF_CACHE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Use soft references {$link java.lang.ref.SoftReference} for the record cache instead of the default normal object references.
SoftCache - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Wraps a deterministic cache policy with a Level-2 cache based on J2SE's soft references.
SoftCache() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Creates a soft-reference based L2 cache with a MRU cache as the internal (L1) cache.
SoftCache(CachePolicy) - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Creates a soft-reference based L2 cache wrapping the specified L1 cache.
SoftCache(float, CachePolicy) - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.SoftCache
Creates a soft-reference based L2 cache wrapping the specified L1 cache.
sortByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SORTCOLS - Static variable in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
sortFieldSchemas(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
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.
splitArgs(String) - Static method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
splitPlan(ReduceSinkOperator, GenMRProcContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Split the current plan by creating a temporary destination
splitTasks(Operator<? extends Serializable>, Task<? extends Serializable>, Task<? extends Serializable>, GenMRProcContext, boolean, boolean, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
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(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(ObjectInspector, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
Call ObjectInspectorFactory.getStandardMapObjectInspector instead.
standardRowInspector - Variable in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
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(List<String>, List<ObjectInspector>) - 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(int, String, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector.MyField
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
start() - Method in class org.apache.hadoop.hive.hwi.HWIServer
This method initialized the internal Jetty Servlet Engine.
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.lazy.LazyNonPrimitive
 
start - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
start() - Method in interface org.apache.hadoop.hive.shims.JettyShims.Server
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
startGroup() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
startQuery(String, String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Called at the start of job Driver.run()
startServer(String, int) - Method in interface org.apache.hadoop.hive.shims.JettyShims
 
startTask(String, Task<? extends Serializable>, String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Called at the start of a task.
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.
state - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
STATE - Static variable in class org.apache.hadoop.hive.service.HiveClusterStatus
 
statement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
staticFlag - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
statsMap - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
stop() - Method in class org.apache.hadoop.hive.hwi.HWIServer
Shut down the running HWI Server
stop() - Method in interface org.apache.hadoop.hive.shims.JettyShims.Server
 
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.
storesLowerCaseIdentifiers() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
storesLowerCaseQuotedIdentifiers() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
storesMixedCaseIdentifiers() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
storesMixedCaseQuotedIdentifiers() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
storesUpperCaseIdentifiers() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
storesUpperCaseQuotedIdentifiers() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
STRING_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
StringComparator - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Comparator for String objects.
StringComparator() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.StringComparator
 
StringLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
StringLiteral - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
StringObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A StringObjectInspector inspects an Object representing a String.
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
 
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
 
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.
Struct() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
STRUCT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
StructField - Interface in org.apache.hadoop.hive.serde2.objectinspector
StructField is an empty interface.
structID - Variable in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
StructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
 
StructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
 
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.
subQuerySource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
SUCCESS - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
supportsAlterTableWithAddColumn() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsAlterTableWithDropColumn() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsANSI92EntryLevelSQL() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsANSI92FullSQL() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsANSI92IntermediateSQL() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsBatchUpdates() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInDataManipulation() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInIndexDefinitions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInPrivilegeDefinitions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInProcedureCalls() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsCatalogsInTableDefinitions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsColumnAliasing() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsConvert() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsConvert(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsCoreSQLGrammar() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsCorrelatedSubqueries() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsDataDefinitionAndDataManipulationTransactions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsDataManipulationTransactionsOnly() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsDifferentTableCorrelationNames() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsExpressionsInOrderBy() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsExtendedSQLGrammar() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsFullOuterJoins() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsGetGeneratedKeys() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsGroupBy() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsGroupByBeyondSelect() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsGroupByUnrelated() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsIntegrityEnhancementFacility() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsLikeEscapeClause() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsLimitedOuterJoins() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsMinimumSQLGrammar() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsMixedCaseIdentifiers() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsMixedCaseQuotedIdentifiers() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsMultipleOpenResults() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsMultipleResultSets() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsMultipleTransactions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsNamedParameters() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsNonNullableColumns() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsOpenCursorsAcrossCommit() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsOpenCursorsAcrossRollback() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsOpenStatementsAcrossCommit() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsOpenStatementsAcrossRollback() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsOrderByUnrelated() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsOuterJoins() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsPositionedDelete() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsPositionedUpdate() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsResultSetConcurrency(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsResultSetHoldability(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsResultSetType(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSavepoints() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInDataManipulation() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInIndexDefinitions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInPrivilegeDefinitions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInProcedureCalls() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSchemasInTableDefinitions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSelectForUpdate() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsStatementPooling() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsStoredFunctionsUsingCallSyntax() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsStoredProcedures() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSubqueriesInComparisons() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSubqueriesInExists() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSubqueriesInIns() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsSubqueriesInQuantifieds() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsTableCorrelationNames() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsTransactionIsolationLevel(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsTransactions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsUnion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
supportsUnionAll() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
SwitchTo(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Switch to specified lex state.
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_INTERVAL - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
The number of bytes between sync points.
synchronizeLog() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.TransactionManager
Synchronize log file data with the main database file.
syncSeen() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns true iff the previous call to next passed a sync mark.
SZ_BYTE - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Size of an externalized byte
SZ_INT - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Size of an externalized int
SZ_LONG - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Size of an externalized long
SZ_SHORT - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
Size of an externalized short

T

tabCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
tabIdEnum - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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>) - 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
Table (only used internally)
Table(String, Properties, Deserializer, Class<? extends InputFormat<?, ?>>, Class<?>, URI, Hive) - Constructor for class org.apache.hadoop.hive.ql.metadata.Table
Table Create a TableMetaInfo object presumably with the intent of saving it to the metastore
Table(String) - Constructor for class org.apache.hadoop.hive.ql.metadata.Table
 
TABLE_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
TABLE_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
tableAllColumns() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableBuckets() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableComment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableDesc - Class in org.apache.hadoop.hive.ql.plan
 
tableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.tableDesc
 
tableDesc(Class<? extends Deserializer>, Class<? extends InputFormat>, Class<?>, Properties) - Constructor for class org.apache.hadoop.hive.ql.plan.tableDesc
 
tableExists(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
tableExists(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
tableFileFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableHandle - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
tableLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TABLENAME - Static variable in class org.apache.hadoop.hive.metastore.api.Index
 
TABLENAME - Static variable in class org.apache.hadoop.hive.metastore.api.Partition
 
TABLENAME - Static variable in class org.apache.hadoop.hive.metastore.api.Table
 
tableName - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
tableOrColumn() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tablePartition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
tables - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
tableSample() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TableSample - Class in org.apache.hadoop.hive.ql.parse
This class stores all the information specified in the TABLESAMPLE clause.
TableSample(String, String, ArrayList<ASTNode>) - Constructor for class org.apache.hadoop.hive.ql.parse.TableSample
Constructs the TableSample given the numerator, denominator and the list of ON clause expressions
TableSample(int, int) - Constructor for class org.apache.hadoop.hive.ql.parse.TableSample
 
tableScanDesc - Class in org.apache.hadoop.hive.ql.plan
Table Scan Descriptor Currently, data is only read from a base source as part of map-reduce framework.
tableScanDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.tableScanDesc
 
tableScanDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.tableScanDesc
 
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
 
tableSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tabName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tabSize - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
tabTypeExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
taskClass - Variable in class org.apache.hadoop.hive.ql.exec.TaskFactory.taskTuple
 
TaskFactory - Class in org.apache.hadoop.hive.ql.exec
TaskFactory implementation
TaskFactory() - Constructor for class org.apache.hadoop.hive.ql.exec.TaskFactory
 
TaskFactory.taskTuple<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
 
TaskFactory.taskTuple(Class<T>, Class<? extends Task<T>>) - Constructor for class org.apache.hadoop.hive.ql.exec.TaskFactory.taskTuple
 
TASKTRACKERS - Static variable in class org.apache.hadoop.hive.service.HiveClusterStatus
 
taskvec - Static variable in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
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
 
TBL - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
TBL_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
TBL_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
TBL_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
TBL_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
TBL_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
TBL_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
TBL_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
TBL_NAME - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
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
 
tearDown() - Method in class org.apache.hadoop.hive.hwi.TestHWIServer
 
tearDown() - Method in class org.apache.hadoop.hive.hwi.TestHWISessionManager
 
tearDown() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
tearDown() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
tearDown() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
tell() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Return the current position.
template - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
templatePath - Variable in class org.apache.hadoop.hive.ant.QTestGenTask
 
TerminalOperator<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
Terminal Operator Base Class
TerminalOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.TerminalOperator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluator
 
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.GenericUDAFCount.GenericUDAFCountEvaluator
 
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.GenericUDAFStd.GenericUDAFStdEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample.GenericUDAFStdSampleEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.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.UDAFAvg.UDAFAvgEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFCount.UDAFCountEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxDoubleEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxFloatEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxIntEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxLongEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxShortEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxStringEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinDoubleEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinFloatEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinIntEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinLongEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinShortEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinStringEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFSum.UDAFSumEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.GenericUDAFAverageEvaluator
 
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.GenericUDAFCount.GenericUDAFCountEvaluator
 
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.GenericUDAFSum.GenericUDAFSumDouble
 
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.UDAFAvg.UDAFAvgEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFCount.UDAFCountEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxDoubleEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxFloatEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxIntEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxLongEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxShortEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxStringEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinDoubleEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinFloatEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinIntEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinLongEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinShortEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFMin.MinStringEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFSum.UDAFSumEvaluator
 
test1ApacheLogFormat() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
Tests a sample apache log format.
testAlterPartition() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testAlterTable() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
TestBinarySortableSerDe - Class in org.apache.hadoop.hive.serde2.binarysortable
 
TestBinarySortableSerDe() - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.TestBinarySortableSerDe
 
testBinarySortableSerDe() - Method in class org.apache.hadoop.hive.serde2.binarysortable.TestBinarySortableSerDe
 
testComplexTable() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testComplexTypeApi() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testConfigurableTCTLSeparated() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
 
testDatabase() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testDatabaseMetaData() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testDescribeTable() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testDriverProperties() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
TestDynamicSerDe - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
TestDynamicSerDe() - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
 
testDynamicSerDe() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
 
testDynamicSerde() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
testExecute() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
testFetch() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
testGetClusterStatus() - Method in class org.apache.hadoop.hive.service.TestHiveServer
Test cluster status retrieval
testHiveDriver() - Method in class org.apache.hadoop.hive.hwi.TestHWISessionManager
 
TestHiveMetaStore - Class in org.apache.hadoop.hive.metastore
 
TestHiveMetaStore() - Constructor for class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
TestHiveServer - Class in org.apache.hadoop.hive.service
 
TestHiveServer(String) - Constructor for class org.apache.hadoop.hive.service.TestHiveServer
 
TestHWIServer - Class in org.apache.hadoop.hive.hwi
 
TestHWIServer(String) - Constructor for class org.apache.hadoop.hive.hwi.TestHWIServer
 
TestHWISessionManager - Class in org.apache.hadoop.hive.hwi
 
TestHWISessionManager(String) - Constructor for class org.apache.hadoop.hive.hwi.TestHWISessionManager
 
testJavaPrimitiveObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestStandardObjectInspectors
 
TestJdbcDriver - Class in org.apache.hadoop.hive.jdbc
 
TestJdbcDriver(String) - Constructor for class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testLazyArray() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyArrayMapStruct
Test the LazyArray class.
TestLazyArrayMapStruct - Class in org.apache.hadoop.hive.serde2.lazy
 
TestLazyArrayMapStruct() - Constructor for class org.apache.hadoop.hive.serde2.lazy.TestLazyArrayMapStruct
 
TestLazyBinarySerDe - Class in org.apache.hadoop.hive.serde2.lazybinary
 
TestLazyBinarySerDe() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.TestLazyBinarySerDe
 
testLazyBinarySerDe() - Method in class org.apache.hadoop.hive.serde2.lazybinary.TestLazyBinarySerDe
The test entrance function
testLazyByte() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
Test the LazyByte class.
testLazyDouble() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
Test the LazyDouble class.
testLazyInteger() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
Test the LazyInteger class.
testLazyIntegerWrite() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
 
testLazyLong() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
Test the LazyLong class.
testLazyLongWrite() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
 
testLazyMap() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyArrayMapStruct
Test the LazyMap class.
TestLazyPrimitive - Class in org.apache.hadoop.hive.serde2.lazy
 
TestLazyPrimitive() - Constructor for class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
 
testLazyShort() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
Test the LazyShort class.
TestLazySimpleSerDe - Class in org.apache.hadoop.hive.serde2.lazy
 
TestLazySimpleSerDe() - Constructor for class org.apache.hadoop.hive.serde2.lazy.TestLazySimpleSerDe
 
testLazySimpleSerDe() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazySimpleSerDe
Test the LazySimpleSerDe class.
testLazySimpleSerDeExtraColumns() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazySimpleSerDe
Test the LazySimpleSerDe class with extra columns.
testLazySimpleSerDeLastColumnTakesRest() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazySimpleSerDe
Test the LazySimpleSerDe class with LastColumnTakesRest option.
testLazySimpleSerDeMissingColumns() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazySimpleSerDe
Test the LazySimpleSerDe class with missing columns.
testLazyString() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyPrimitive
Test the LazyString class.
testLazyStruct() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyArrayMapStruct
Test the LazyStruct class.
testMetastore() - Method in class org.apache.hadoop.hive.service.TestHiveServer
Test metastore call
testNonHiveCommand() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
testNulls() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
testNulls1() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
Tests a single null list within a struct with return nulls on
testNulls2() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
Tests all elements of a struct being null with return nulls on
testNulls3() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
Tests map and list being empty with return nulls on
testNulls4() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
Tests map and list null/empty with return nulls *off*
TestObjectInspectorConverters - Class in org.apache.hadoop.hive.serde2.objectinspector
 
TestObjectInspectorConverters() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestObjectInspectorConverters
 
testObjectInspectorConverters() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestObjectInspectorConverters
 
TestObjectInspectorUtils - Class in org.apache.hadoop.hive.serde2.objectinspector
 
TestObjectInspectorUtils() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestObjectInspectorUtils
 
testObjectInspectorUtils() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestObjectInspectorUtils
 
testPartition() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
tests create table and partition and tries to drop the table without droppping the partition
testQuotedWrites() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
testReads() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
TestReflectionObjectInspectors - Class in org.apache.hadoop.hive.serde2.objectinspector
 
TestReflectionObjectInspectors() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestReflectionObjectInspectors
 
testReflectionObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestReflectionObjectInspectors
 
testResultSetMetaData() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testSelectAll() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testSelectAllMaxRows() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testSelectAllPartioned() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testServerInit() - Method in class org.apache.hadoop.hive.hwi.TestHWIServer
 
testShowTables() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testSimpleTable() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testSimpleTypeApi() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testSkip() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
 
testStandardListObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestStandardObjectInspectors
 
testStandardMapObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestStandardObjectInspectors
 
TestStandardObjectInspectors - Class in org.apache.hadoop.hive.serde2.objectinspector
 
TestStandardObjectInspectors() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestStandardObjectInspectors
 
testStandardPrimitiveObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestStandardObjectInspectors
 
testStandardStructObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestStandardObjectInspectors
 
testStructsinStructs() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
Tests map and list null/empty with return nulls *off*
testTBinarySortableProtocol() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
 
TestTCTLSeparatedProtocol - Class in org.apache.hadoop.hive.serde2
 
TestTCTLSeparatedProtocol() - Constructor for class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
TestThriftObjectInspectors - Class in org.apache.hadoop.hive.serde2.objectinspector
 
TestThriftObjectInspectors() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestThriftObjectInspectors
 
testThriftObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestThriftObjectInspectors
 
TestUnionStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
 
TestUnionStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestUnionStructObjectInspector
 
testUnionStructObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestUnionStructObjectInspector
 
testWrites() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
THREAD_SAFE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Option to create a thread-safe record manager.
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
 
ThriftByteStreamTypedSerDe - Class in org.apache.hadoop.hive.serde2.thrift
 
ThriftByteStreamTypedSerDe(Type, TProtocolFactory, TProtocolFactory) - Constructor for class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
ThriftDeserializer - Class in org.apache.hadoop.hive.serde2.thrift
 
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.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.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_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.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_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.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_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.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_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.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_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.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_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.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_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.Iface - Interface in org.apache.hadoop.hive.service
 
ThriftHive.Processor - Class in org.apache.hadoop.hive.service
 
ThriftHive.Processor(ThriftHive.Iface) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Processor
 
ThriftHiveMetastore - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore
 
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_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.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_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_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_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.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_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.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.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(String, String) - 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_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(boolean, AlreadyExistsException, 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_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_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_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_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.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) - 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_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(boolean, 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_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_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_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_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_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_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) - 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.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_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_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(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_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_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_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_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_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_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_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) - 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_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_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_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_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_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_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_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_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_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_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_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_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) - 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.Iface - Interface in org.apache.hadoop.hive.metastore.api
This interface is live.
ThriftHiveMetastore.Processor - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor(ThriftHiveMetastore.Iface) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor
 
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.
thriftWriterFname - Static variable in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
Throttle - Class in org.apache.hadoop.hive.ql.exec
 
Throttle() - Constructor for class org.apache.hadoop.hive.ql.exec.Throttle
 
Throws() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TILDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TILDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TIMESTAMP_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
TINYINT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
TOK_ALIASLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALIASLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALLCOLREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALLCOLREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_ADDCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_ADDCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_ADDPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_DROPPARTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_RENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_REPLACECOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_REPLACECOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_SERDEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_SERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_SERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_BIGINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_BOOLEAN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_byte - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_CHARSETLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CHARSETLITERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CLUSTERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CLUSTERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_cocoa_prefix - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
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_CREATEFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CREATEFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CREATETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_csharp_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DATETIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DESCFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DESCFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DESCTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DESCTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DESTINATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DESTINATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DISTRIBUTEBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DISTRIBUTEBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DOUBLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_DROPFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DROPFUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DROPTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_EXPLAIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_EXPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_EXPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_FALSE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_FLOAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_FROM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FULLOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_FULLOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_FUNCTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_FUNCTIONDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_FUNCTIONDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_GROUPBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_HINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_HINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_HINTARGLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_HINTARGLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_HINTLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_HINTLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_IFNOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_IFNOTEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_include - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_INSERT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_INT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_int_constant - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_ISNOTNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ISNOTNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ISNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ISNULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_JOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LEFTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_LEFTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LIKETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_LIKETABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_LIMIT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_LOAD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_LOCAL_DIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_LOCAL_DIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_MAP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_MSCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_NULL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_ADD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_AND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_BITAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_BITAND - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_BITNOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_BITNOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_BITOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_BITOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_BITXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_BITXOR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_DIV - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_EQ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_EQ - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_GE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_GE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_GT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_GT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_LE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_LE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_LIKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_LT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_LT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_MOD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_MUL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_MUL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_NE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_NE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_NOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_OR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_OP_SUB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OP_SUB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_ORDERBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PARTITIONLOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PARTITIONLOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PARTSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PARTSPEC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PARTVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PARTVAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_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.HiveLexer
 
TOK_QUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_required - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_RIGHTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_RIGHTOUTERJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SELECTDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SELECTDI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SELEXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SELEXPR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SERDENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SERDENAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SERDEPROPS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SERDEPROPS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_SHOWFUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOWFUNCTIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWPARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOWPARTITIONS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWTABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOWTABLES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_SMALLINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_SORTBY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_st_identifier - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_STRING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_string - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
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.HiveLexer
 
TOK_SUBQUERY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TAB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TAB - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABCOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOLLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABCOLLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABCOLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABCOLNAME - 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.HiveLexer
 
TOK_TABLE_OR_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEBUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEBUCKETS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEFILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEFILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLELOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEPARTCOLS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEPROPERTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEPROPERTY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEROWFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATCOLLITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEROWFORMATCOLLITEMS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATFIELD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEROWFORMATFIELD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATLINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEROWFORMATLINES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLEROWFORMATMAPKEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLEROWFORMATMAPKEYS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLESAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLESAMPLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABLESERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLESERIALIZER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABREF - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABSORTCOLNAMEASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABSORTCOLNAMEASC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABSORTCOLNAMEDESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABSORTCOLNAMEDESC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TABTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TBLRCFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TBLRCFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TBLSEQUENCEFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TBLSEQUENCEFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TBLTEXTFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TBLTEXTFILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_TIMESTAMP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TINYINT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TMP_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TMP_FILE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TRANSFORM - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TRUE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_typedef - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_UNION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_UNION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_USERSCRIPTCOLNAMES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_USERSCRIPTCOLNAMES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_USERSCRIPTCOLSCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_USERSCRIPTCOLSCHEMA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.HiveLexer
 
TOK_WHERE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_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.ql.parse.HiveParser
 
Tokens - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TokenToTypeName - Static variable in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
toString() - Method in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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 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.MetaException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
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.Schema
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.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_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.append_partition_args
 
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.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_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_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.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_partition_args
 
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_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_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.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_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_partition_args
 
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_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_partitions_args
 
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_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_table_args
 
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_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.Type
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
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.hooks.ReadEntity
toString function.
toString() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
toString function.
toString() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
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.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.parse.BaseSemanticAnalyzer.tableSpec
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
toString() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeColumnDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeConstantDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFieldDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.exprNodeFuncDesc
 
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.util.jdbm.recman.BlockIo
 
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.columnar.BytesRefWritable
toString() - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe
 
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.ByteWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
toString() - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
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.LazySimpleStructObjectInspector.MyField
 
toString() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryPrimitive
 
toString() - Method in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
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.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.typeinfo.TypeInfo
 
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.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.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
 
totalSz - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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
touchEntry(CacheEntry) - Method in class org.apache.hadoop.hive.ql.util.jdbm.helper.MRU
Place entry at the end of linked list -- Most Recently Used
toXML() - Method in class org.apache.hadoop.hive.ql.plan.mapredWork
 
TransactionManager - Class in org.apache.hadoop.hive.ql.util.jdbm.recman
This class manages the transaction log that belongs to every RecordFile.
TransactionManager.BlockIoComparator - Class in org.apache.hadoop.hive.ql.util.jdbm.recman
INNER CLASS.
TransactionManager.BlockIoComparator() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.recman.TransactionManager.BlockIoComparator
 
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.MapJoinProcessor
Transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
Transform - Interface in org.apache.hadoop.hive.ql.optimizer
Optimizer interface.
transform(ParseContext) - Method in interface org.apache.hadoop.hive.ql.optimizer.Transform
All transformation steps implement this interface
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcessor
Transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.ppd.PredicatePushDown
 
TRANSLATION_PAGE - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
 
transportTokenizer - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The transport stream is tokenized on the row separator
TReflectionUtils - Class in org.apache.hadoop.hive.serde2.thrift
 
TReflectionUtils() - Constructor for class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
trfmClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Tuple - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Tuple consisting of a key-value pair.
Tuple() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.Tuple
Construct an empty Tuple.
Tuple(Object, Object) - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.Tuple
Construct a Tuple.
TupleBrowser - Class in org.apache.hadoop.hive.ql.util.jdbm.helper
Browser to traverse a collection of tuples.
TupleBrowser() - Constructor for class org.apache.hadoop.hive.ql.util.jdbm.helper.TupleBrowser
 
TYPE - Static variable in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
TYPE - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
TYPE - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
Type - Class in org.apache.hadoop.hive.metastore.api
 
Type() - Constructor for class org.apache.hadoop.hive.metastore.api.Type
 
Type(String, String, String, List<FieldSchema>) - 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() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TYPE1 - Static variable in class org.apache.hadoop.hive.metastore.api.Type
 
TYPE2 - Static variable in class org.apache.hadoop.hive.metastore.api.Type
 
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.
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.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.parse
The default processor for typechecking.
TypeCheckProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
TypeCheckProcFactory.NullExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for processing NULL expression.
TypeCheckProcFactory.NullExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.NullExprProcessor
 
TypeCheckProcFactory.NumExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for processing numeric constants.
TypeCheckProcFactory.NumExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.NumExprProcessor
 
TypeCheckProcFactory.StrExprProcessor - Class in org.apache.hadoop.hive.ql.parse
Processor for processing string constants.
TypeCheckProcFactory.StrExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.StrExprProcessor
 
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
 
TypeDouble() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TypedSerDe - Class in org.apache.hadoop.hive.serde2
 
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 - Class in org.apache.hadoop.hive.serde2.typeinfo
Stores information about a type.
TypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
 
TypeInfoFactory - Class in org.apache.hadoop.hive.serde2.typeinfo
TypeInfoFactory can be used to create the TypeInfo object for any types.
TypeInfoFactory() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
TypeInfoUtils - Class in org.apache.hadoop.hive.serde2.typeinfo
 
TypeInfoUtils() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
 
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.
types - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
TypeSet() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
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
Base class for all User-defined Aggregation Function (UDAF) classes.
UDAF() - Constructor for class org.apache.hadoop.hive.ql.exec.UDAF
The default constructor.
UDAF(UDAFEvaluatorResolver) - Constructor for class org.apache.hadoop.hive.ql.exec.UDAF
The constructor with a particular type of resolver.
UDAFAvg - Class in org.apache.hadoop.hive.ql.udf
 
UDAFAvg() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFAvg
 
UDAFAvg.UDAFAvgEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFAvg.UDAFAvgEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFAvg.UDAFAvgEvaluator
 
UDAFCount - Class in org.apache.hadoop.hive.ql.udf
 
UDAFCount() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFCount
 
UDAFCount.UDAFCountEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFCount.UDAFCountEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFCount.UDAFCountEvaluator
 
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.
UDAFMax - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMax() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMax
 
UDAFMax.MaxDoubleEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMax.MaxDoubleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxDoubleEvaluator
 
UDAFMax.MaxFloatEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMax.MaxFloatEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxFloatEvaluator
 
UDAFMax.MaxIntEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMax.MaxIntEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxIntEvaluator
 
UDAFMax.MaxLongEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMax.MaxLongEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxLongEvaluator
 
UDAFMax.MaxShortEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMax.MaxShortEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxShortEvaluator
 
UDAFMax.MaxStringEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMax.MaxStringEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMax.MaxStringEvaluator
 
UDAFMin - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMin
 
UDAFMin.MinDoubleEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMin.MinDoubleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMin.MinDoubleEvaluator
 
UDAFMin.MinFloatEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMin.MinFloatEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMin.MinFloatEvaluator
 
UDAFMin.MinIntEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMin.MinIntEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMin.MinIntEvaluator
 
UDAFMin.MinLongEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMin.MinLongEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMin.MinLongEvaluator
 
UDAFMin.MinShortEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMin.MinShortEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMin.MinShortEvaluator
 
UDAFMin.MinStringEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFMin.MinStringEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFMin.MinStringEvaluator
 
UDAFSum - Class in org.apache.hadoop.hive.ql.udf
 
UDAFSum() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFSum
 
UDAFSum.UDAFSumEvaluator - Class in org.apache.hadoop.hive.ql.udf
 
UDAFSum.UDAFSumEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFSum.UDAFSumEvaluator
 
UDF - Class in org.apache.hadoop.hive.ql.exec
A User-defined function (UDF) for the use with Hive.
UDF() - Constructor for class org.apache.hadoop.hive.ql.exec.UDF
The constructor
UDF(UDFMethodResolver) - Constructor for class org.apache.hadoop.hive.ql.exec.UDF
The constructor with user-provided UDFMethodResolver.
UDFAbs - Class in org.apache.hadoop.hive.ql.udf
 
UDFAbs() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAbs
 
UDFAcos - Class in org.apache.hadoop.hive.ql.udf
 
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
 
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() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAscii
 
UDFAsin - Class in org.apache.hadoop.hive.ql.udf
 
UDFAsin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAsin
 
UDFBaseBitOP - Class in org.apache.hadoop.hive.ql.udf
Base class for numeric operators like +, -, / etc.
UDFBaseBitOP() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBaseBitOP
Constructor.
UDFBaseCompare - Class in org.apache.hadoop.hive.ql.udf
 
UDFBaseCompare() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBaseCompare
This constructor sets the resolver to be used for comparison operators.
UDFBaseNumericOp - Class in org.apache.hadoop.hive.ql.udf
Base class for numeric operators like +, -, / etc.
UDFBaseNumericOp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBaseNumericOp
Constructor.
UDFBaseNumericUnaryOp - Class in org.apache.hadoop.hive.ql.udf
Base class for numeric operators like +, -, / etc.
UDFBaseNumericUnaryOp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBaseNumericUnaryOp
Constructor.
UDFBin - Class in org.apache.hadoop.hive.ql.udf
 
UDFBin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBin
 
UDFCeil - Class in org.apache.hadoop.hive.ql.udf
 
UDFCeil() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFCeil
 
UDFConcat - Class in org.apache.hadoop.hive.ql.udf
 
UDFConcat() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFConcat
 
UDFConv - Class in org.apache.hadoop.hive.ql.udf
 
UDFConv() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFConv
 
UDFCos - Class in org.apache.hadoop.hive.ql.udf
 
UDFCos() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFCos
 
UDFDate - Class in org.apache.hadoop.hive.ql.udf
 
UDFDate() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDate
 
UDFDateAdd - Class in org.apache.hadoop.hive.ql.udf
 
UDFDateAdd() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDateAdd
 
UDFDateDiff - Class in org.apache.hadoop.hive.ql.udf
 
UDFDateDiff() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDateDiff
 
UDFDateSub - Class in org.apache.hadoop.hive.ql.udf
 
UDFDateSub() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDateSub
 
UDFDayOfMonth - Class in org.apache.hadoop.hive.ql.udf
 
UDFDayOfMonth() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDayOfMonth
 
UDFExp - Class in org.apache.hadoop.hive.ql.udf
 
UDFExp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFExp
 
UDFFloor - Class in org.apache.hadoop.hive.ql.udf
 
UDFFloor() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFFloor
 
UDFFromUnixTime - Class in org.apache.hadoop.hive.ql.udf
 
UDFFromUnixTime() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
 
UDFHex - Class in org.apache.hadoop.hive.ql.udf
 
UDFHex() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFHex
 
UDFJson - Class in org.apache.hadoop.hive.ql.udf
 
UDFJson() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFJson
 
UDFLength - Class in org.apache.hadoop.hive.ql.udf
 
UDFLength() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLength
 
UDFLike - Class in org.apache.hadoop.hive.ql.udf
 
UDFLike() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLike
 
UDFLn - Class in org.apache.hadoop.hive.ql.udf
 
UDFLn() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLn
 
UDFLog - Class in org.apache.hadoop.hive.ql.udf
 
UDFLog() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog
 
UDFLog10 - Class in org.apache.hadoop.hive.ql.udf
 
UDFLog10() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog10
 
UDFLog2 - Class in org.apache.hadoop.hive.ql.udf
 
UDFLog2() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog2
 
UDFLower - Class in org.apache.hadoop.hive.ql.udf
 
UDFLower() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLower
 
UDFLpad - Class in org.apache.hadoop.hive.ql.udf
 
UDFLpad() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLpad
 
UDFLTrim - Class in org.apache.hadoop.hive.ql.udf
 
UDFLTrim() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLTrim
 
UDFMethodResolver - Interface in org.apache.hadoop.hive.ql.exec
The UDF Method resolver interface.
UDFMonth - Class in org.apache.hadoop.hive.ql.udf
 
UDFMonth() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFMonth
 
UDFOPAnd - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPAnd() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPAnd
 
UDFOPBitAnd - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPBitAnd() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
UDFOPBitNot - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPBitNot() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
UDFOPBitOr - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPBitOr() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
UDFOPBitXor - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPBitXor() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
UDFOPDivide - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPDivide() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPDivide
 
UDFOPEqual - Class in org.apache.hadoop.hive.ql.udf
The reason that we list evaluate methods with all numeric types is for better performance; otherwise a single method that takes (Number a, Number b) and use a.doubleValue() == b.doubleValue() is enough.
UDFOPEqual() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPEqual
 
UDFOPEqualOrGreaterThan - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPEqualOrGreaterThan() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrGreaterThan
 
UDFOPEqualOrLessThan - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPEqualOrLessThan() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPEqualOrLessThan
 
UDFOPGreaterThan - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPGreaterThan() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPGreaterThan
 
UDFOPLessThan - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPLessThan() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPLessThan
 
UDFOPLongDivide - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPLongDivide() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPLongDivide
 
UDFOPMinus - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPMinus() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPMinus
 
UDFOPMod - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPMod() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPMod
 
UDFOPMultiply - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPMultiply() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPMultiply
 
UDFOPNegative - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPNegative() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPNegative
 
UDFOPNot - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPNot() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPNot
 
UDFOPNotEqual - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPNotEqual() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPNotEqual
 
UDFOPOr - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPOr() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPOr
 
UDFOPPlus - Class in org.apache.hadoop.hive.ql.udf
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.
UDFOPPlus() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPPlus
 
UDFOPPositive - Class in org.apache.hadoop.hive.ql.udf
 
UDFOPPositive() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPPositive
 
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
 
UDFPosMod - Class in org.apache.hadoop.hive.ql.udf
class for computing positive modulo.
UDFPosMod() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFPosMod
 
UDFPower - Class in org.apache.hadoop.hive.ql.udf
 
UDFPower() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFPower
 
UDFRand - Class in org.apache.hadoop.hive.ql.udf
 
UDFRand() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRand
 
UDFRegExp - Class in org.apache.hadoop.hive.ql.udf
 
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() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRegExpReplace
 
UDFRepeat - Class in org.apache.hadoop.hive.ql.udf
 
UDFRepeat() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRepeat
 
UDFReverse - Class in org.apache.hadoop.hive.ql.udf
 
UDFReverse() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFReverse
 
UDFRound - Class in org.apache.hadoop.hive.ql.udf
 
UDFRound() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRound
 
UDFRpad - Class in org.apache.hadoop.hive.ql.udf
 
UDFRpad() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRpad
 
UDFRTrim - Class in org.apache.hadoop.hive.ql.udf
 
UDFRTrim() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRTrim
 
UDFSin - Class in org.apache.hadoop.hive.ql.udf
 
UDFSin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSin
 
UDFSpace - Class in org.apache.hadoop.hive.ql.udf
 
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() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
UDFToBoolean - Class in org.apache.hadoop.hive.ql.udf
 
UDFToBoolean() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToBoolean
 
UDFToByte - Class in org.apache.hadoop.hive.ql.udf
 
UDFToByte() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToByte
 
UDFToDate - Class in org.apache.hadoop.hive.ql.udf
 
UDFToDate() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToDate
 
UDFToDouble - Class in org.apache.hadoop.hive.ql.udf
 
UDFToDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToDouble
 
UDFToFloat - Class in org.apache.hadoop.hive.ql.udf
 
UDFToFloat() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToFloat
 
UDFToInteger - Class in org.apache.hadoop.hive.ql.udf
 
UDFToInteger() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToInteger
 
UDFToLong - Class in org.apache.hadoop.hive.ql.udf
 
UDFToLong() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToLong
 
UDFToShort - Class in org.apache.hadoop.hive.ql.udf
 
UDFToShort() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToShort
 
UDFToString - Class in org.apache.hadoop.hive.ql.udf
 
UDFToString() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToString
 
UDFTrim - Class in org.apache.hadoop.hive.ql.udf
 
UDFTrim() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFTrim
 
UDFType - Annotation Type in org.apache.hadoop.hive.ql.udf
 
UDFUnixTimeStamp - Class in org.apache.hadoop.hive.ql.udf
 
UDFUnixTimeStamp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFUnixTimeStamp
 
UDFUpper - Class in org.apache.hadoop.hive.ql.udf
 
UDFUpper() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFUpper
 
UDFYear - Class in org.apache.hadoop.hive.ql.udf
 
UDFYear() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFYear
 
unCheckedGet(int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Gets the BytesRefWritable at the specified position without checking.
uncheckedGetField(int, Text) - Method in class org.apache.hadoop.hive.serde2.columnar.ColumnarStruct
Get the field out of the row without checking parsed.
underscore_int - Variable in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
UNDERSCORE_INT - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
unescapeIdentifier(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Remove the encapsulating "`" pair from the identifier.
unescapeSQLString(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
UnflagArgs() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
unionDesc - Class in org.apache.hadoop.hive.ql.plan
unionDesc is a empty class currently.
unionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.unionDesc
 
UnionOperator - Class in org.apache.hadoop.hive.ql.exec
Union Operator Just forwards.
UnionOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.UnionOperator
 
UnionProcContext - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
 
UnionProcContext() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
UnionProcContext.UnionParseContext - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
 
UnionProcContext.UnionParseContext(int) - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
UnionProcessor - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Implementation of the union processor.
UnionProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcessor
empty constructor
UnionProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Operator factory for union processing
UnionProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
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.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(List<StructObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
UnionStructObjectInspector.MyField - Class in org.apache.hadoop.hive.serde2.objectinspector
 
UnionStructObjectInspector.MyField(int, StructField) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
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.
unknownListTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
unknownListTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
unknownMapTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
unknownMapTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
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.
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
 
unregisterJar(String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
unregisterTemporaryUDF(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
unsetAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetBucketCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetCol() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
unsetColNames() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetComment() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
unsetComments() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
unsetCompressed() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.append_partition_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.get_fields_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_names_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_schema_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.drop_table_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_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_table_args
 
unsetDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetDescription() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_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.getSchema_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
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
 
unsetIndexName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetIndexType() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetInputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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
 
unsetLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
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_partitions_args
 
unsetMaxMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetMaxReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
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.MetaException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
unsetMessage() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
unsetMStringString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
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.create_database_args
 
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.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
 
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.alter_partition_args
 
unsetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
unsetNumBuckets() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetNumRows() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
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.alter_partition_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.append_partition_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_table_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.drop_partition_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.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_fields_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_partitions_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_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_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.alter_partition_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.append_partition_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_table_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.drop_database_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_type_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_partition_names_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_schema_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_type_all_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_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.append_partition_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_type_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.get_fields_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
unsetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
unsetOrder() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
unsetOutputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetOwner() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
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_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.drop_partition_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
unsetPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetPartName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
unsetProperties() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
unsetQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
unsetReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetRetention() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetSerdeInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetSerializationLib() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
unsetSortCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
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.append_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_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.drop_database_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_type_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_fields_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_partitions_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_table_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.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.getSchema_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
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_schema_args
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_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_table_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.drop_partition_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_names_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_table_args
 
unsetType() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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
 
unsetType1() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
unsetType2() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
unsetUnderscore_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
unsetValues() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetVersion() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
update(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Update returnObjectInspector and valueInspectorsAreTheSame based on the ObjectInspector seen.
update(long, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Updates a record using standard java object serialization.
update(long, Object, Serializer) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BaseRecordManager
Updates a record using a custom serializer.
update(long, Object) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Updates a record using standard Java serialization.
update(long, Object, Serializer) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Updates a record using a custom serializer.
update(long, Object) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Updates a record using standard java object serialization.
update(long, Object, Serializer) - Method in interface org.apache.hadoop.hive.ql.util.jdbm.RecordManager
Updates a record using a custom serializer.
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.hadoop.hive.jdbc.HiveResultSet
 
updateArray(String, Array) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateAsciiStream(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateAsciiStream(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateAsciiStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateAsciiStream(String, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateAsciiStream(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateAsciiStream(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBigDecimal(int, BigDecimal) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBigDecimal(String, BigDecimal) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBinaryStream(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBinaryStream(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBinaryStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBinaryStream(String, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBinaryStream(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBinaryStream(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBlob(int, Blob) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBlob(String, Blob) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBlob(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBlob(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBlob(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBlob(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBoolean(int, boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBoolean(String, boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateByte(int, byte) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateByte(String, byte) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBytes(int, byte[]) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateBytes(String, byte[]) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateCacheEntries() - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Update all dirty cache objects to the underlying RecordManager.
updateCharacterStream(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateCharacterStream(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateCharacterStream(int, Reader, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateCharacterStream(String, Reader, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateCharacterStream(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateCharacterStream(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateClob(int, Clob) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateClob(String, Clob) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateClob(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateClob(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateClob(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateClob(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateDate(int, Date) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateDate(String, Date) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateDouble(int, double) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateDouble(String, double) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateFloat(int, float) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateFloat(String, float) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateInt(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateInt(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
UpdateLineColumn(char) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
updateLong(int, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateLong(String, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNCharacterStream(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNCharacterStream(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNCharacterStream(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNCharacterStream(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNClob(int, NClob) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNClob(String, NClob) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNClob(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNClob(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNClob(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNClob(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNString(int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNString(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNull(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateNull(String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateObject(int, Object) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateObject(String, Object) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateObject(int, Object, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateObject(String, Object, int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateRef(int, Ref) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateRef(String, Ref) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateRow() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateRowId(int, RowId) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateRowId(String, RowId) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updatesAreDetected(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
updateShort(int, short) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateShort(String, short) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateSQLXML(int, SQLXML) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateSQLXML(String, SQLXML) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateString(int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateString(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateTime(int, Time) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateTime(String, Time) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateTimestamp(int, Timestamp) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
updateTimestamp(String, Timestamp) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
usage() - Static method in class org.apache.hadoop.hive.serde2.thrift_test.CreateSequenceFile
 
USED_PAGE - Static variable in interface org.apache.hadoop.hive.ql.util.jdbm.recman.Magic
 
usesJobShell() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Return true if the current version of Hadoop uses the JobShell for command line interpretation.
usesLocalFilePerTable() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
usesLocalFiles() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
Utilities - Class in org.apache.hadoop.hive.ql.exec
 
Utilities() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities
 
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.ReduceField - Enum in org.apache.hadoop.hive.ql.exec
The object in the reducer are composed of these top level fields
Utilities.StreamPrinter - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.StreamPrinter(InputStream, String, PrintStream) - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.StreamPrinter
 
Utilities.streamStatus - Enum in org.apache.hadoop.hive.ql.exec
 
Utilities.Tuple<T,V> - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.Tuple(T, V) - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.Tuple
 

V

valClass - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
VALID_VALUES - Static variable in class org.apache.hadoop.hive.service.JobTrackerState
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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 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.MetaException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
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.Schema
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.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_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.append_partition_args
 
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.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_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_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.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_partition_args
 
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_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_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.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_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_partition_args
 
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_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_partitions_args
 
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_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_table_args
 
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_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.Type
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
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.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.service.HiveClusterStatus
 
validate() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
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.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
 
validateColNames(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
validateFile(Set<String>, String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
validateInput(JobConf) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
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.RCFileInputFormat
 
validateInput(FileSystem, HiveConf, ArrayList<FileStatus>) - Method in class org.apache.hadoop.hive.ql.io.SequenceFileInputFormatChecker
 
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]+".
value - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VInt
 
value - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VLong
 
valueEval - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
The evaluators for the value columns.
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.hwi.HWISessionItem.WebSessionItemStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.FileSinkOperator.TableIdEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.FilterOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.FunctionInfo.OperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.MapOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Operator.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.ScriptOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.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.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.ReadEntity.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.hooks.WriteEntity.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.ErrorMsg
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.QBExpr.Opcode
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.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.PlanUtils.ExpressionTypes
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.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.PrimitiveObjectInspector.PrimitiveCategory
Returns the enum constant of this type with the specified name.
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.hwi.HWISessionItem.WebSessionItemStatus
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in class org.apache.hadoop.hive.metastore.api.Partition
 
values() - Static method in enum org.apache.hadoop.hive.ql.exec.FileSinkOperator.TableIdEnum
Returns 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.FilterOperator.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.FunctionInfo.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.exec.MapOperator.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Operator.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.ScriptOperator.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.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.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.ReadEntity.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.WriteEntity.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.parse.ErrorMsg
Returns 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.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.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.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.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.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() - Method in class org.apache.hadoop.hive.ql.util.jdbm.htree.HTree
Returns an enumeration of the values contained in this
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.PrimitiveObjectInspector.PrimitiveCategory
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES_TO_NAMES - Static variable in class org.apache.hadoop.hive.service.JobTrackerState
 
varname - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
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 - Static variable in class org.apache.hadoop.hive.metastore.api.Version
 
VOID_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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
 

W

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.PreOrderWalker
walk the current operator and its descendants
walk(Node) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPruner.ColumnPrunerWalker
Walk the given operator
walk(Node) - Method in class org.apache.hadoop.hive.ql.parse.GenMapRedWalker
Walk the given operator
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
 
wasNull() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
wasNull() - Method in class org.apache.hadoop.hive.jdbc.HiveResultSet
 
WEAK_REF_CACHE - Static variable in class org.apache.hadoop.hive.ql.util.jdbm.RecordManagerOptions
Use weak references {$link java.lang.ref.WeakReference} for the record cache instead of the default normal object references.
whenExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
whereClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
work - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
workClass - Variable in class org.apache.hadoop.hive.ql.exec.TaskFactory.taskTuple
 
WrappedRuntimeException - Exception in org.apache.hadoop.hive.ql.util.jdbm.helper
A run-time exception that wraps another exception.
WrappedRuntimeException(String, Exception) - Constructor for exception org.apache.hadoop.hive.ql.util.jdbm.helper.WrappedRuntimeException
Constructs a new runtime exception based on a checked exception.
WrappedRuntimeException(Exception) - Constructor for exception org.apache.hadoop.hive.ql.util.jdbm.helper.WrappedRuntimeException
Constructs a new runtime exception based on a checked exception.
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.
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.
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.
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(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(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
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 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.MetaException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
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.Schema
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.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_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.append_partition_args
 
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.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_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_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.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_partition_args
 
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_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_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.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_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_partition_args
 
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_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_partitions_args
 
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_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_table_args
 
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_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.Type
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
write(Writable) - Method in interface org.apache.hadoop.hive.ql.exec.FileSinkOperator.RecordWriter
 
write(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(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(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
write(byte, boolean) - Method in class org.apache.hadoop.hive.serde2.binarysortable.OutputByteBuffer
Write one byte to the byte buffer.
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.ByteWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.DoubleWritable
 
write(DataOutput) - Method in class org.apache.hadoop.hive.serde2.io.ShortWritable
 
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.service.HiveClusterStatus
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
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.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
 
writeBinary(byte[]) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBinary(byte[]) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeBool(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBool(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeByte(int, byte) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Writes a byte to the indicated position
writeByte(byte) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeByte(byte) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeDataTo(DataOutput) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 
writeDouble(double) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeDouble(double) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
WriteEntity - Class in org.apache.hadoop.hive.ql.hooks
This class encapsulates an object that is being written to by the query.
WriteEntity(Table) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a table.
WriteEntity(Partition) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a partition.
WriteEntity(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a file.
WriteEntity.Type - Enum in org.apache.hadoop.hive.ql.hooks
The type of the write entity.
writeExternal(ObjectOutput) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectKey
 
writeExternal(ObjectOutput) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinObjectValue
 
writeExternal(ObjectOutput) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
 
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
 
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, int) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Writes an int to the indicated position
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
 
writeLong(int, long) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Writes a long to the indicated position
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
 
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.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.
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.
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(int, short) - Method in class org.apache.hadoop.hive.ql.util.jdbm.recman.BlockIo
Writes a short to the indicated position
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.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).
writeTo(OutputStream) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
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.
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
 
writeVInt(ByteStream.Output, int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Writes a zero-compressed encoded int to a byte array.
writeVLong(ByteStream.Output, long) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Write a zero-compressed encoded long to a byte array.
WS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
WS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 

X

Xception() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 

Z

ZeroBytesRefWritable - Static variable in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 

_

_cache - Variable in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Cache for underlying RecordManager
_nested - Variable in exception org.apache.hadoop.hive.ql.util.jdbm.helper.CacheEvictionException
Nested exception -- the original exception that occured, if any.
_recman - Variable in class org.apache.hadoop.hive.ql.util.jdbm.recman.CacheRecordManager
Wrapped RecordManager

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 © 2009 The Apache Software Foundation