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 ...
abortWriters(FileSystem, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
absolute(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
AbstractGenericUDAFResolver - Class in org.apache.hadoop.hive.ql.udf.generic
An abstract class to help facilitate existing implementations of GenericUDAFResolver to migrate towards the newly introduced interface GenericUDAFResolver2.
AbstractGenericUDAFResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDAFResolver
 
AbstractIndexHandler - Class in org.apache.hadoop.hive.ql.index
Abstract base class for index handlers.
AbstractIndexHandler() - Constructor for class org.apache.hadoop.hive.ql.index.AbstractIndexHandler
 
AbstractMapJoinKey - Class in org.apache.hadoop.hive.ql.exec.persistence
Map Join Object used for both key.
AbstractMapJoinKey() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinKey
 
AbstractMapJoinOperator<T extends MapJoinDesc> - Class in org.apache.hadoop.hive.ql.exec
 
AbstractMapJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
AbstractMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc>) - Constructor for class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
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
 
AbstractRowContainer<Row> - Class in org.apache.hadoop.hive.ql.exec.persistence
 
AbstractRowContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
AbstractSemanticAnalyzerHook - Class in org.apache.hadoop.hive.ql.parse
 
AbstractSemanticAnalyzerHook() - Constructor for class org.apache.hadoop.hive.ql.parse.AbstractSemanticAnalyzerHook
 
accept(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask.DisabledQFileFilter
 
accept(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask.QFileFilter
 
accept(File) - Method in class org.apache.hadoop.hive.ant.QTestGenTask.QFileRegexFilter
 
acceptImpl() - Method in class org.apache.hadoop.hive.metastore.TServerSocketKeepAlive
 
acceptsURL(String) - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
Checks whether a given url is in a valid format.
acquireReadWriteLocks() - Method in class org.apache.hadoop.hive.ql.Driver
Acquire read and write locks needed by the statement.
adaptor - Variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
add(Row) - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
add(Row) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
add(Row) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
add(TypeInfo) - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
add(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Adds a new n-gram to the estimation.
add(double) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Adds a new data point to the histogram approximation.
add_escapes(String) - Method in exception org.apache.hadoop.hive.serde2.dynamic_type.ParseException
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
add_index(Index, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_index(Index, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_index(Index, Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_index(Index, Table) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_index(Index, Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
add_partition(Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
add_partition(Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
add_partition(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
add_partition(Partition) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
add_partition(Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
add_partition(Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
add_partition(Partition) - 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
 
add_resource(SessionState.ResourceType, String, boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
addAggregationExprsForClause(String, LinkedHashMap<String, ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
addAlias(ExprNodeDesc, String) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
Adds the specified alias to the specified expr.
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
 
addComparisonOp(String) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Registers a comparison operator as one which can be satisfied by an index search.
addCompleteTask(TaskRunner) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
addConvertedNode(ExprNodeDesc, ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
adds a replacement node for this expression.
addCS(String, ContentSummary) - Method in class org.apache.hadoop.hive.ql.Context
 
addDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
Add a dependent task on the current conditional task.
addDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
Add a dependent task on the current task.
addDummyParentOp(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
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
addFile(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
addFile(File) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
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
 
addIndex(Index) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addIndex(Index) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
addIntermediateNode(ExpressionTree.LogicalOperator) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
Adds a intermediate node of either type(AND/OR).
addLateralViewForAlias(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addLeafNode(ExpressionTree.LeafNode) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
Adds a leaf node, pushes the new node onto the stack.
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
 
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() - Constructor for class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
For serialization only.
AddPartitionDesc(String, String, Map<String, String>, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
addQuery(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Adds a new query to the execution list.
AddResourceProcessor - Class in org.apache.hadoop.hive.ql.processors
AddResourceProcessor.
AddResourceProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
addRHSSemijoin(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
Insert only a key to the semijoin table name to column names map.
addRHSSemijoinColumns(String, ArrayList<ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
Remeber the mapping of table alias to set of columns.
addRHSSemijoinColumns(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
Remeber the mapping of table alias to set of columns.
addRole(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
addRole(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
addTableSpec(String, BaseSemanticAnalyzer.tableSpec) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
addTaskAttemptLogUrl(String) - Method in class org.apache.hadoop.hive.ql.exec.errors.TaskLogProcessor
Adds a task log URL for the heuristics to read through.
addTaskTmpDir(String) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
addToAdjacencyList(Adjacency) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
addToBucketCols(String) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
addToChildren(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
addToClassPath(ClassLoader, String[]) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Add new elements to the classpath.
addToCols(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
addToDispatchList(Node) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker.TaskGraphWalkerContext
 
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
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
addToGroup_names(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
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
 
addToOperatorList(Operator) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
addToPart_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
addToPartitionKeys(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
addToPartValues(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
addToPrivileges(HiveObjectPrivilege) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
addToQueries(Query) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
addToRoots(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
addToRootTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
addToRunnable(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
addToSortCols(Order) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
addToStageList(Stage) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
addToSuccess(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
addToSuccess(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
addToSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
addToSuccess(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
addToSuccess(HiveObjectPrivilege) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
addToSuccess(Role) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
addToSuccess(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
addToTaskList(Task) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
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.
Adjacency - Class in org.apache.hadoop.hive.ql.plan.api
 
Adjacency() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
Adjacency(String, List<String>, AdjacencyType) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
Adjacency(Adjacency) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Adjacency
Performs a deep copy on other.
Adjacency._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AdjacencyType - Enum in org.apache.hadoop.hive.ql.plan.api
 
adjustArraySize(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryMap
Adjust the size of arrays: keyStart, keyLength valueStart, valueLength keyInited, keyIsNull valueInited, valueIsNull.
adjustBeginLineColumn(int, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
afterLast() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.
aggregateStats(String, String) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
aggregateStats(String, String) - Method in interface org.apache.hadoop.hive.ql.stats.StatsAggregator
This method aggregates a given statistic from all tasks (partial stats).
AggregationDesc - Class in org.apache.hadoop.hive.ql.plan
AggregationDesc.
AggregationDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
AggregationDesc(String, GenericUDAFEvaluator, ArrayList<ExprNodeDesc>, boolean, GenericUDAFEvaluator.Mode) - Constructor for class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
alias - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
alias - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
alias - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
aliasList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ALL - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
allInitializedParentsAreClosed() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
allInitializedParentsAreClosed() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
allocate(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Sets the number of histogram bins to use for approximating data.
allocatePartitionDescMap() - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
allowColumnName(String) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Adds a column name to the set of column names allowed.
allProceduresAreCallable() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
ALLSCOPE - Static variable in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
 
ALLSCOPE_EXCEPT_COLUMN - Static variable in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
 
allTablesAreSelectable() - Method in class org.apache.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.
AlreadyExistsException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
alter_database(String, Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_database_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_database(String, Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_database_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_database(String, Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_database(String, Database) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_database(String, Database) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_index(String, String, String, Index, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_index(String, String, String, Index, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_index(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_index(String, String, String, Index) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_index(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_index(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_index(String, String, String, Index) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
alter_partition(String, String, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_partition(String, String, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_partition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_partition(String, String, Partition) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_partition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_partition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_partition(String, String, Partition) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
updates a partition to new partition
alter_table(String, String, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
alter_table(String, String, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
alter_table(String, String, Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
alter_table(String, String, Table) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
alter_table(String, String, Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
alter_table(String, String, Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alter_table(String, String, Table) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
alterDatabase(String, Database) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
alterDatabase(String, Database) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
alterDatabase(String, Database) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
Alter the database object in metastore.
alterDatabase(String, Database) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
alterDatabase(String, Database) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
AlterDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
AlterDatabaseDesc.
AlterDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
For serialization only.
AlterDatabaseDesc(String, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
AlterDatabaseDesc(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
alterDatabaseStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterDatabaseSuffixProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
AlterHandler - Interface in org.apache.hadoop.hive.metastore
Interface for Alter Table and Alter Partition code
alterIndex(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
alterIndex(String, String, String, Index) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
alterIndex(String, String, String, Index) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing index metadata with the new metadata.
AlterIndexDesc - Class in org.apache.hadoop.hive.ql.plan
AlterIndexDesc.
AlterIndexDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
AlterIndexDesc(AlterIndexDesc.AlterIndexTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
AlterIndexDesc.AlterIndexTypes - Enum in org.apache.hadoop.hive.ql.plan
alterIndexTypes.
alterIndexStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
alterPartition(String, Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Updates the existing table metadata with the new metadata.
alterProtectMode() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterProtectModeMode() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementChangeColPosition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixAddCol() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixAddPartitions() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixArchive() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixClusterbySortby() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixDropPartitions() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixFileFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixProtectMode() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixRename() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixRenameCol() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixSerdeProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixTouch() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterStatementSuffixUnArchive() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.
AlterTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, String, String, String, String, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, List<FieldSchema>, AlterTableDesc.AlterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(AlterTableDesc.AlterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(AlterTableDesc.AlterTableTypes, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, String, String, String, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, int, List<String>, List<Order>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc(String, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
AlterTableDesc.AlterTableTypes - Enum in org.apache.hadoop.hive.ql.plan
alterTableTypes.
AlterTableDesc.ProtectModeType - Enum in org.apache.hadoop.hive.ql.plan
 
AlterTableSimpleDesc - Class in org.apache.hadoop.hive.ql.plan
Contains information needed to modify a partition or a table
AlterTableSimpleDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
AlterTableSimpleDesc(String, String, Map<String, String>, AlterTableDesc.AlterTableTypes) - Constructor for class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
alterTableStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterTblPartitionStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterTblPartitionStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterViewStatementSuffix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
alterViewSuffixProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
AmbiguousMethodException - Exception in org.apache.hadoop.hive.ql.exec
Exception thrown by the UDF and UDAF method resolvers in case a unique method is not found.
AmbiguousMethodException(Class<?>, List<TypeInfo>, List<Method>) - Constructor for exception org.apache.hadoop.hive.ql.exec.AmbiguousMethodException
Constructor.
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
 
analyzeAST(ASTNode) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
analyzeIndexDefinition(Table, Index, Table) - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
analyzeIndexDefinition(Table, Index, Table) - Method in interface org.apache.hadoop.hive.ql.index.HiveIndexHandler
Requests that the handler validate an index definition and fill in additional information about its stored representation.
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
analyzeInternal(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.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
 
analyzePredicate(ExprNodeDesc, List<IndexSearchCondition>) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Analyzes a predicate.
analyzeStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
append(JobCloseFeedBack.FeedBackType, Object) - Method in class org.apache.hadoop.hive.ql.exec.JobCloseFeedBack
 
append(Writable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
Append a row of values.
append_partition(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
append_partition(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
append_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
append_partition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
append_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
append_partition_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
append_partition_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
append_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
append_partition_by_name(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
append_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
appendPartition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendPartition(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
appendPartition(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
appendPartitionByName(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
appendReadColumnIDs(Configuration, ArrayList<Integer>) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
Sets read columns' ids(start from zero) for RCFile's Reader.
appendTmpPath(String) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
Append a subdirectory to the tmp path.
applySystemProperties() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
ArchiveDesc - Class in org.apache.hadoop.hive.ql.plan
ArchiveDesc.
ArchiveDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ArchiveDesc
 
ArchiveWork - Class in org.apache.hadoop.hive.ql.plan
ArchiveWork.
ArchiveWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ArchiveWork
 
ArchiveWork.ArchiveActionType - Enum in org.apache.hadoop.hive.ql.plan
 
areAllParentsInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Operator
checks whether all parent operators are initialized or not.
areEqual(Object[], Object[]) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ListObjectsEqualComparer
ol0, ol1 should have equal or less number of elements than objectinspectors passed in constructor.
argumentOIs - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
assignCounterNameToEnum() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Called only in SemanticAnalyzer after all operators have added their own set of counter names.
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.
ASTNodeOrigin - Class in org.apache.hadoop.hive.ql.parse
ASTNodeOrigin contains contextual information about the object from whose definition a particular ASTNode originated.
ASTNodeOrigin(String, String, String, String, ASTNode) - Constructor for class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
ASTRING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
Async() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
atomExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
AUDIT_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
auditLog - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
augmentPlan() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
augmentPlan() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Called during semantic analysis as operators are being added in order to give them a chance to compute any additional plan information needed.
authenticator - Variable in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
AuthorizationException - Exception in org.apache.hadoop.hive.ql.metadata
 
AuthorizationException() - Constructor for exception org.apache.hadoop.hive.ql.metadata.AuthorizationException
 
AuthorizationException(String) - Constructor for exception org.apache.hadoop.hive.ql.metadata.AuthorizationException
Constructs an AuthorizationException with the specified detail message.
AuthorizationException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.metadata.AuthorizationException
Constructs an AuthorizationException with the specified cause.
AuthorizationException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.metadata.AuthorizationException
 
authorize(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
authorize(Database, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
authorize(Table, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
authorize(Partition, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
authorize(Table, Partition, List<String>, Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
authorize(Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization user level privileges.
authorize(Database, Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization privileges against a database object.
authorize(Table, Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization privileges against a hive table object.
authorize(Partition, Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization privileges against a hive partition object.
authorize(Table, Partition, List<String>, Privilege[], Privilege[]) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
Authorization privileges against a list of columns.
authorizePrivileges(PrincipalPrivilegeSet, Privilege[], boolean[], Privilege[], boolean[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
authorizeUserPriv(Privilege[], boolean[], Privilege[], boolean[]) - Method in class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
autoCommitFailureClosesAllResultSets() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
autoDelete - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
AutoProgressor - Class in org.apache.hadoop.hive.ql.exec
AutoProgressor periodically sends updates to the job tracker so that it doesn't consider this task attempt dead if there is a long period of inactivity.
autoRebuild() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
auxJars - Variable in class org.apache.hadoop.hive.conf.HiveConf
 
available() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream

B

backup(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
BACKUP_COMMON_JOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
backupChildrenTasks - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
backupTask - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
baseOI - Variable in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
BaseSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
BaseSemanticAnalyzer.
BaseSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
BaseSemanticAnalyzer.tableSpec - Class in org.apache.hadoop.hive.ql.parse
tableSpec.
BaseSemanticAnalyzer.tableSpec(Hive, HiveConf, ASTNode) - Constructor for class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
BaseSemanticAnalyzer.tableSpec.SpecType - Enum in org.apache.hadoop.hive.ql.parse
 
beforeFirst() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.
beginTime - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
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
 
BinaryRecordReader - Class in org.apache.hadoop.hive.ql.exec
Read from a binary stream and treat each 1000 bytes (configurable via hive.binary.record.max.length) as a record.
BinaryRecordReader() - Constructor for class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
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
 
BLOCKOFFSET - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
body() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
boi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
boi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
BOOLEAN_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
 
BucketizedHiveInputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
BucketizedHiveInputFormat serves the similar function as hiveInputFormat but its getSplits() always group splits from one input file into one wrapper split.
BucketizedHiveInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
BucketizedHiveInputSplit - Class in org.apache.hadoop.hive.ql.io
HiveInputSplit encapsulates an InputSplit with its corresponding inputFormatClass.
BucketizedHiveInputSplit() - Constructor for class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
BucketizedHiveInputSplit(InputSplit[], String) - Constructor for class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
BucketizedHiveRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
BucketizedHiveRecordReader is a wrapper on a list of RecordReader.
BucketizedHiveRecordReader(InputFormat, BucketizedHiveInputSplit, JobConf, Reporter) - Constructor for class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
BucketMapJoinOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
this transformation does bucket map join optimization.
BucketMapJoinOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.BucketMapJoinOptimizer
 
BucketMatcher - Interface in org.apache.hadoop.hive.ql.exec
 
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
 
byoi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
byoi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
ByteArrayRef - Class in org.apache.hadoop.hive.serde2.lazy
ByteArrayRef stores a reference to a byte array.
ByteArrayRef() - Constructor for class org.apache.hadoop.hive.serde2.lazy.ByteArrayRef
 
byteArrayToInt(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Convert the byte array to an int starting from the given offset.
byteArrayToLong(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Convert the byte array to a long starting from the given offset.
byteArrayToShort(byte[], int) - Static method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils
Convert the byte array to a short starting from the given offset.
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.
BytesRefWritable(LazyDecompressionCallback, int, int) - Constructor for class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Create a BytesRefWritable referenced to one section of the given bytes.
ByteStream - Class in org.apache.hadoop.hive.serde2
Extensions to bytearrayinput/output streams.
ByteStream() - Constructor for class org.apache.hadoop.hive.serde2.ByteStream
 
ByteStream.Input - Class in org.apache.hadoop.hive.serde2
Input.
ByteStream.Input() - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Input
 
ByteStream.Input(byte[]) - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Input
 
ByteStream.Input(byte[], int, int) - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Input
 
ByteStream.Output - Class in org.apache.hadoop.hive.serde2
Output.
ByteStream.Output() - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Output
 
ByteStream.Output(int) - Constructor for class org.apache.hadoop.hive.serde2.ByteStream.Output
 
ByteStreamTypedSerDe - Class in org.apache.hadoop.hive.serde2
ByteStreamTypedSerDe.
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.
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.
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

cachedMap - Variable in class org.apache.hadoop.hive.serde2.lazy.LazyMap
cachedMap is reused for different calls to getMap().
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
 
cancel_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
cancel_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
cancel_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
cancel_delegation_token(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
cancel_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
cancelDelegationToken(String) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Discard a current delegation token.
cancelDelegationToken(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
cancelDelegationToken(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
cancelDelegationToken(String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
cancelRowUpdates() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
canDrop() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
canDrop() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
canWrite() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
canWrite() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
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
 
checkCliDriverResults(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
checkFatalErrors(Counters, StringBuilder) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Recursively check this operator and its descendants to see if the fatal error counter is set to non-zero.
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.
checkMapJoin(int, JoinCondDesc[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
checkMetastore(String, String, List<? extends Map<String, String>>, CheckResult) - Method in class org.apache.hadoop.hive.ql.metadata.HiveMetaStoreChecker
Check the metastore for inconsistencies, data missing in either the metastore or on the dfs.
checkNegativeResults(String, Exception) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
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.
checkParseResults(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
checkPlan(String, List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
CheckResult - Class in org.apache.hadoop.hive.ql.metadata
Result class used by the HiveMetaStoreChecker.
CheckResult() - Constructor for class org.apache.hadoop.hive.ql.metadata.CheckResult
 
CheckResult.PartitionResult - Class in org.apache.hadoop.hive.ql.metadata
A basic description of a partition that is missing from either the fs or the ms.
CheckResult.PartitionResult() - Constructor for class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
checkValidity() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
childErr - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Error output from any child process(es).
childOperators - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
childOperatorsArray - Variable in class org.apache.hadoop.hive.ql.exec.Operator
Cache childOperators in an array for faster access.
childOperatorsTag - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
childOut - Variable in class org.apache.hadoop.hive.ql.session.SessionState
Standard output from any child process(es).
children - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
childTasks - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
clean(HiveConf) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
cleanUp(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.StatsTask
This method is static as it is called from the shutdown hook at the ExecDriver.
cleanUp() - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
cleanUp(String) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
cleanUp(String) - Method in interface org.apache.hadoop.hive.ql.stats.StatsAggregator
This method clears the temporary statistics that have been published without being aggregated.
cleanUpInputFileChanged() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
cleanUpInputFileChangedOp() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
clear() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
clear() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
clear() - Method in class org.apache.hadoop.hive.ql.Context
 
clear() - Static method in class org.apache.hadoop.hive.ql.exec.MapJoinMetaData
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
Remove all elements in the RowContainer.
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
Remove all elements in the RowContainer.
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MRU
Clear all elements in the MRU list.
clear() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
Remove all elements in the RowContainer.
clear() - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
clear() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
clear() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
clear() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
clear() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Removes all elements.
clear(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableMapObjectInspector
Clear the map.
clear(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
clear() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
clear() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
clear() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
clear() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
clear() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
clearAllowedColumnNames() - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Clears the set of column names allowed in comparisons.
clearBatch() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
clearBatch() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
clearBatch() - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
clearFetch() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
Clear the Fetch Operator.
clearFetchContext() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Clear the context, if anything needs to be done.
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
 
clearPostTestEffects() - Method in class org.apache.hadoop.hive.ql.QTestUtil
Clear out any side effects of running tests
clearQueries() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
clearSerDeInfo() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
clearTestSideEffects() - Method in class org.apache.hadoop.hive.ql.QTestUtil
Clear out any side effects of running tests
clearWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.HiveStatement
 
CliDriver - Class in org.apache.hadoop.hive.cli
CliDriver.
CliDriver() - Constructor for class org.apache.hadoop.hive.cli.CliDriver
 
client - Static variable in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
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.
cliInit(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
cliInit(String, boolean) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
CliSessionState - Class in org.apache.hadoop.hive.cli
CliSessionState.
CliSessionState() - Constructor for class org.apache.hadoop.hive.cli.CliSessionState
 
CliSessionState(HiveConf) - Constructor for class org.apache.hadoop.hive.cli.CliSessionState
 
clone() - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
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.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
 
cloneConf() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
clonedConf - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
cloneGenericUDF(GenericUDF) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Create a copy of an existing GenericUDF.
cloneGenericUDTF(GenericUDTF) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Create a copy of an existing GenericUDTF.
close() - Method in class org.apache.hadoop.hive.common.metrics.Metrics.MetricsScope
Closes scope, and records the time taken
close() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.HiveMetaDataResultSet
 
close() - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
Closes the prepared statement.
close() - Method in class org.apache.hadoop.hive.jdbc.HiveQueryResultSet
 
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.BinaryRecordReader
 
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() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
Close the persistent hash table and clean it up.
close() - Method in interface org.apache.hadoop.hive.ql.exec.RecordReader
 
close() - Method in interface org.apache.hadoop.hive.ql.exec.RecordWriter
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
close(boolean) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
close() - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.exec.TextRecordWriter
 
close() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
close() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
close(Reporter) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter
 
close(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 interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
close() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Called to notify the UDTF that there are no more rows to process.
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
close() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
close() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
closeConnection() - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
closeConnection() - Method in interface org.apache.hadoop.hive.ql.stats.StatsAggregator
This method closes the connection to the temporary storage.
closeConnection() - Method in interface org.apache.hadoop.hive.ql.stats.StatsPublisher
This method closes the connection to the temporary storage.
closeCurrent() - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
closeFs(FileSystem) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
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.HashTableDummyOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
All done.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.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.
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
closeOp(boolean) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
closeWriters(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
clusterByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.
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.
collect(Object) - Method in interface org.apache.hadoop.hive.ql.udf.generic.Collector
Other classes will call collect() with the data that it has.
collect(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.UDTFCollector
 
CollectDesc - Class in org.apache.hadoop.hive.ql.plan
CollectDesc.
CollectDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CollectDesc
 
CollectDesc(Integer) - Constructor for class org.apache.hadoop.hive.ql.plan.CollectDesc
 
COLLECTION_DELIM - Static variable in class org.apache.hadoop.hive.serde.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
 
Collector - Interface in org.apache.hadoop.hive.ql.udf.generic
Collector gets data from a source.
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
 
colType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
colTypeList() - 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
 
COLUMNAR_SERDE - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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.
ColumnarStruct(ObjectInspector, ArrayList<Integer>, Text) - 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
 
ColumnInfo(String, TypeInfo, String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
columnName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameColonType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameColonTypeList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameComment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameCommentList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameOrder() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameOrderList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNames - Variable in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
columnNameType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
columnNameTypeList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ColumnProjectionUtils - Class in org.apache.hadoop.hive.serde2
ColumnProjectionUtils.
ColumnPruner - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of one of the rule-based optimization steps.
ColumnPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPruner
empty constructor.
ColumnPruner.ColumnPrunerWalker - Class in org.apache.hadoop.hive.ql.optimizer
Walks the op tree in post order fashion (skips selects with file sink or script op children).
ColumnPruner.ColumnPrunerWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPruner.ColumnPrunerWalker
 
ColumnPrunerProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
This class implements the processor context for Column Pruner.
ColumnPrunerProcCtx(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.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.ColumnPrunerLateralViewJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Lateral View Join Operators.
ColumnPrunerProcFactory.ColumnPrunerLateralViewJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerLateralViewJoinProc
 
ColumnPrunerProcFactory.ColumnPrunerMapJoinProc - Class in org.apache.hadoop.hive.ql.optimizer
The Node Processor for Column Pruning on Map Join Operators.
ColumnPrunerProcFactory.ColumnPrunerMapJoinProc() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerMapJoinProc
 
ColumnPrunerProcFactory.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.
ColumnSet() - Constructor for class org.apache.hadoop.hive.serde2.ColumnSet
 
ColumnSet(ArrayList<String>) - Constructor for class org.apache.hadoop.hive.serde2.ColumnSet
 
columnTypes - Variable in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
CombineHiveInputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
CombineHiveInputFormat is a parameterized InputFormat which looks at the path name and determine the correct InputFormat for that path name from mapredPlan.pathToPartitionInfo().
CombineHiveInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat
 
CombineHiveInputFormat.CombineHiveInputSplit - Class in org.apache.hadoop.hive.ql.io
CombineHiveInputSplit encapsulates an InputSplit with its corresponding inputFormatClassName.
CombineHiveInputFormat.CombineHiveInputSplit() - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveInputFormat.CombineHiveInputSplit(HadoopShims.InputSplitShim) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveInputFormat.CombineHiveInputSplit(JobConf, HadoopShims.InputSplitShim) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
CombineHiveRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
CombineHiveRecordReader.
CombineHiveRecordReader(InputSplit, Configuration, Reporter, Integer) - Constructor for class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
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.
CommandProcessorResponse - Class in org.apache.hadoop.hive.ql.processors
Encapsulates the basic response info returned by classes the implement the CommandProcessor interfaace.
CommandProcessorResponse(int) - Constructor for class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
CommandProcessorResponse(int, String, String) - Constructor for class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
CommaOrSemicolon() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
COMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
commit() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
commitCreateTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called after successfully adding a new table definition to the metastore during CREATE TABLE.
commitDropTable(Table, boolean) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called after successfully removing a table definition from the metastore during DROP TABLE.
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.
COMMON_JOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
CommonJoinOperator<T extends JoinDesc> - Class in org.apache.hadoop.hive.ql.exec
Join operator implementation.
CommonJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
CommonJoinOperator(CommonJoinOperator<T>) - Constructor for class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
CommonJoinOperator.IntermediateObject - Class in org.apache.hadoop.hive.ql.exec
IntermediateObject.
CommonJoinOperator.IntermediateObject(ArrayList<Object>[], int) - Constructor for class org.apache.hadoop.hive.ql.exec.CommonJoinOperator.IntermediateObject
 
CommonJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
 
CommonJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.CommonJoinResolver
 
commonKey - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
CompactIndexHandler - Class in org.apache.hadoop.hive.ql.index.compact
 
CompactIndexHandler() - Constructor for class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
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(Map.Entry<LineageInfo.DependencyKey, LineageInfo.Dependency>, Map.Entry<LineageInfo.DependencyKey, LineageInfo.Dependency>) - Method in class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter.DependencyKeyComp
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.HiveKey.Comparator
Compare the buffers in serialized form.
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj.Comparator
 
compare(Map.Entry<LongWritable, LongWritable>, Map.Entry<LongWritable, LongWritable>) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.MyComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.io.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.
compareOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
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.
compareRaw(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.io.RecordTestObj.Comparator
 
compareSupported(ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Whether comparison is supported for this type.
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
to support sorting/Set.
compareTo(AlreadyExistsException) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
compareTo(ConfigValSecurityException) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
compareTo(Database) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
compareTo(FieldSchema) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
compareTo(HiveObjectPrivilege) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
compareTo(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
compareTo(Index) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
compareTo(IndexAlreadyExistsException) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
compareTo(InvalidObjectException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
compareTo(InvalidOperationException) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
compareTo(MetaException) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
compareTo(NoSuchObjectException) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
compareTo(Order) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
compareTo(Partition) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
compareTo(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
compareTo(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
compareTo(PrivilegeGrantInfo) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
compareTo(Role) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
compareTo(Schema) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
compareTo(SerDeInfo) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
compareTo(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
compareTo(Table) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
compareTo(ThriftHiveMetastore.add_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
compareTo(ThriftHiveMetastore.add_index_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
compareTo(ThriftHiveMetastore.add_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
compareTo(ThriftHiveMetastore.add_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
compareTo(ThriftHiveMetastore.alter_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
compareTo(ThriftHiveMetastore.alter_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
compareTo(ThriftHiveMetastore.alter_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
compareTo(ThriftHiveMetastore.alter_index_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
compareTo(ThriftHiveMetastore.alter_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
compareTo(ThriftHiveMetastore.alter_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
compareTo(ThriftHiveMetastore.alter_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
compareTo(ThriftHiveMetastore.alter_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
compareTo(ThriftHiveMetastore.append_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
compareTo(ThriftHiveMetastore.append_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
compareTo(ThriftHiveMetastore.append_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
compareTo(ThriftHiveMetastore.append_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
compareTo(ThriftHiveMetastore.cancel_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
compareTo(ThriftHiveMetastore.cancel_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
compareTo(ThriftHiveMetastore.create_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
compareTo(ThriftHiveMetastore.create_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
compareTo(ThriftHiveMetastore.create_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
compareTo(ThriftHiveMetastore.create_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
compareTo(ThriftHiveMetastore.create_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
compareTo(ThriftHiveMetastore.create_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
compareTo(ThriftHiveMetastore.create_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
compareTo(ThriftHiveMetastore.create_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
compareTo(ThriftHiveMetastore.drop_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
compareTo(ThriftHiveMetastore.drop_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
compareTo(ThriftHiveMetastore.drop_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
compareTo(ThriftHiveMetastore.drop_index_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
compareTo(ThriftHiveMetastore.drop_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
compareTo(ThriftHiveMetastore.drop_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
compareTo(ThriftHiveMetastore.drop_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
compareTo(ThriftHiveMetastore.drop_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
compareTo(ThriftHiveMetastore.drop_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
compareTo(ThriftHiveMetastore.drop_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
compareTo(ThriftHiveMetastore.drop_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
compareTo(ThriftHiveMetastore.drop_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
compareTo(ThriftHiveMetastore.drop_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
compareTo(ThriftHiveMetastore.drop_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
compareTo(ThriftHiveMetastore.get_all_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
compareTo(ThriftHiveMetastore.get_all_databases_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
compareTo(ThriftHiveMetastore.get_all_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
compareTo(ThriftHiveMetastore.get_all_tables_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
compareTo(ThriftHiveMetastore.get_config_value_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
compareTo(ThriftHiveMetastore.get_config_value_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
compareTo(ThriftHiveMetastore.get_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
compareTo(ThriftHiveMetastore.get_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
compareTo(ThriftHiveMetastore.get_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
compareTo(ThriftHiveMetastore.get_databases_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
compareTo(ThriftHiveMetastore.get_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
compareTo(ThriftHiveMetastore.get_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
compareTo(ThriftHiveMetastore.get_delegation_token_with_signature_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
compareTo(ThriftHiveMetastore.get_delegation_token_with_signature_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
compareTo(ThriftHiveMetastore.get_fields_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
compareTo(ThriftHiveMetastore.get_fields_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
compareTo(ThriftHiveMetastore.get_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
compareTo(ThriftHiveMetastore.get_index_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
compareTo(ThriftHiveMetastore.get_index_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
compareTo(ThriftHiveMetastore.get_index_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
compareTo(ThriftHiveMetastore.get_indexes_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
compareTo(ThriftHiveMetastore.get_indexes_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
compareTo(ThriftHiveMetastore.get_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
compareTo(ThriftHiveMetastore.get_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
compareTo(ThriftHiveMetastore.get_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
compareTo(ThriftHiveMetastore.get_partition_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
compareTo(ThriftHiveMetastore.get_partition_names_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
compareTo(ThriftHiveMetastore.get_partition_names_ps_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
compareTo(ThriftHiveMetastore.get_partition_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
compareTo(ThriftHiveMetastore.get_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
compareTo(ThriftHiveMetastore.get_partition_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
compareTo(ThriftHiveMetastore.get_partition_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
compareTo(ThriftHiveMetastore.get_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
compareTo(ThriftHiveMetastore.get_partitions_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
compareTo(ThriftHiveMetastore.get_partitions_by_filter_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
compareTo(ThriftHiveMetastore.get_partitions_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
compareTo(ThriftHiveMetastore.get_partitions_ps_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
compareTo(ThriftHiveMetastore.get_partitions_ps_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
compareTo(ThriftHiveMetastore.get_partitions_ps_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
compareTo(ThriftHiveMetastore.get_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
compareTo(ThriftHiveMetastore.get_partitions_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
compareTo(ThriftHiveMetastore.get_partitions_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
compareTo(ThriftHiveMetastore.get_privilege_set_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
compareTo(ThriftHiveMetastore.get_privilege_set_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
compareTo(ThriftHiveMetastore.get_role_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
compareTo(ThriftHiveMetastore.get_role_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
compareTo(ThriftHiveMetastore.get_schema_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
compareTo(ThriftHiveMetastore.get_schema_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
compareTo(ThriftHiveMetastore.get_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
compareTo(ThriftHiveMetastore.get_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
compareTo(ThriftHiveMetastore.get_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
compareTo(ThriftHiveMetastore.get_tables_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
compareTo(ThriftHiveMetastore.get_type_all_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
compareTo(ThriftHiveMetastore.get_type_all_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
compareTo(ThriftHiveMetastore.get_type_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
compareTo(ThriftHiveMetastore.get_type_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
compareTo(ThriftHiveMetastore.grant_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
compareTo(ThriftHiveMetastore.grant_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
compareTo(ThriftHiveMetastore.grant_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
compareTo(ThriftHiveMetastore.grant_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
compareTo(ThriftHiveMetastore.list_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
compareTo(ThriftHiveMetastore.list_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
compareTo(ThriftHiveMetastore.list_roles_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
compareTo(ThriftHiveMetastore.list_roles_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
compareTo(ThriftHiveMetastore.partition_name_to_spec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
compareTo(ThriftHiveMetastore.partition_name_to_spec_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
compareTo(ThriftHiveMetastore.partition_name_to_vals_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
compareTo(ThriftHiveMetastore.partition_name_to_vals_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
compareTo(ThriftHiveMetastore.renew_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
compareTo(ThriftHiveMetastore.renew_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
compareTo(ThriftHiveMetastore.revoke_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
compareTo(ThriftHiveMetastore.revoke_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
compareTo(ThriftHiveMetastore.revoke_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
compareTo(ThriftHiveMetastore.revoke_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
compareTo(Type) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
compareTo(UnknownDBException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
compareTo(UnknownTableException) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
compareTo(Version) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
compareTo(Object) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
Compares two ByteWritables.
compareTo(Object) - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
compareTo(CheckResult.PartitionResult) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
compareTo(Adjacency) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
compareTo(Graph) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
compareTo(Operator) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
compareTo(Query) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
compareTo(QueryPlan) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
compareTo(Stage) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
compareTo(Task) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
compareTo(InnerStruct) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
compareTo(ThriftTestObj) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
compareTo(BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
compareTo(BytesRefWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
compareTo(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
 
compareTo(Complex) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
compareTo(IntString) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
compareTo(HiveClusterStatus) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
compareTo(HiveServerException) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
compareTo(ThriftHive.execute_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
compareTo(ThriftHive.execute_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
compareTo(ThriftHive.fetchAll_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
compareTo(ThriftHive.fetchAll_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
compareTo(ThriftHive.fetchN_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
compareTo(ThriftHive.fetchN_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
compareTo(ThriftHive.fetchOne_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
compareTo(ThriftHive.fetchOne_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
compareTo(ThriftHive.getClusterStatus_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
compareTo(ThriftHive.getClusterStatus_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
compareTo(ThriftHive.getQueryPlan_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
compareTo(ThriftHive.getQueryPlan_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
compareTo(ThriftHive.getSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
compareTo(ThriftHive.getSchema_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
compareTo(ThriftHive.getThriftSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
compareTo(ThriftHive.getThriftSchema_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
compareType - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
compareTypes(ObjectInspector, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Compares two types identified by the given object inspectors.
ComparisonOpMethodResolver - Class in org.apache.hadoop.hive.ql.exec
The class implements the method resolution for operators like (> < <= >= = <>).
ComparisonOpMethodResolver(Class<? extends UDF>) - Constructor for class org.apache.hadoop.hive.ql.exec.ComparisonOpMethodResolver
Constuctor.
compile(String) - Method in class org.apache.hadoop.hive.ql.Driver
Compile a new query.
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.
Complex._Fields - Enum in org.apache.hadoop.hive.serde2.thrift.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Complexpb - Class in org.apache.hadoop.hive.serde2.proto.test
 
Complexpb.Complex - Class in org.apache.hadoop.hive.serde2.proto.test
 
Complexpb.Complex(int, String, List<Integer>, List<String>, List<Complexpb.IntString>) - Constructor for class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
Complexpb.IntString - Class in org.apache.hadoop.hive.serde2.proto.test
 
Complexpb.IntString(int, String, int) - Constructor for class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
complexSplit(String, Pattern) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Split the line based on a complex regex pattern.
computeKeys(Object, List<ExprNodeEvaluator>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Return the key as a standard object.
computeMapJoinKeys(Object, List<ExprNodeEvaluator>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Return the key as a standard object.
computeMapJoinValues(Object, List<ExprNodeEvaluator>, List<ObjectInspector>, List<ExprNodeEvaluator>, List<ObjectInspector>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Return the value as a standard object.
computeValues(Object, List<ExprNodeEvaluator>, List<ObjectInspector>, List<ExprNodeEvaluator>, List<ObjectInspector>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Return the value as a standard object.
ConditionalResolver - Interface in org.apache.hadoop.hive.ql.plan
Conditional task resolution interface.
ConditionalResolverCommonJoin - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverSkewJoin.
ConditionalResolverCommonJoin() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin
 
ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverSkewJoinCtx.
ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
ConditionalResolverMergeFiles - Class in org.apache.hadoop.hive.ql.plan
Conditional task resolution interface.
ConditionalResolverMergeFiles() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles
 
ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverMergeFilesCtx.
ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx(List<Task<? extends Serializable>>, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
ConditionalResolverSkewJoin - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverSkewJoin.
ConditionalResolverSkewJoin() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin
 
ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx - Class in org.apache.hadoop.hive.ql.plan
ConditionalResolverSkewJoinCtx.
ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
For serialization use only.
ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx(HashMap<String, Task<? extends Serializable>>) - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
 
ConditionalTask - Class in org.apache.hadoop.hive.ql.exec
Conditional Task implementation.
ConditionalTask() - Constructor for class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
ConditionalWork - Class in org.apache.hadoop.hive.ql.plan
ConditionalWork.
ConditionalWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalWork
 
ConditionalWork(List<? extends Serializable>) - Constructor for class org.apache.hadoop.hive.ql.plan.ConditionalWork
 
condn - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
conds - Variable in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
conds - Variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
conf - Variable in class org.apache.hadoop.hive.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.optimizer.physical.PhysicalContext
 
conf - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
conf - Variable in class org.apache.hadoop.hive.ql.QTestUtil
 
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
 
configure(JobConf) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
 
configureTableJobProperties(TableDesc, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
configureTableJobProperties(TableDesc, Map<String, String>) - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
Configures properties for a job based on the definition of the source or target table it accesses.
configureTableJobPropertiesForStorageHandler(TableDesc) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Loads the storage handler (if one exists) for the given table and invokes HiveStorageHandler.configureTableJobProperties(org.apache.hadoop.hive.ql.plan.TableDesc, java.util.Map).
ConfigValSecurityException - Exception in org.apache.hadoop.hive.metastore.api
 
ConfigValSecurityException() - Constructor for exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
ConfigValSecurityException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
ConfigValSecurityException(ConfigValSecurityException) - Constructor for exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
Performs a deep copy on other.
ConfigValSecurityException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
connect(String, Properties) - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
 
connect(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
connect(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
connect(Configuration) - Method in interface org.apache.hadoop.hive.ql.stats.StatsAggregator
This method connects to the temporary storage.
connect(Configuration) - Method in interface org.apache.hadoop.hive.ql.stats.StatsPublisher
This method connects to the intermediate statistics database.
console - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
console - Variable in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
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
 
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(FileSplit) - Method in class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexResult
 
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
 
ContentSummaryInputFormat - Interface in org.apache.hadoop.hive.ql.io
ContentSummayInputFormat provides an interface to let the input format itself figure the content summary for a give input path.
Context - Class in org.apache.hadoop.hive.ql
Context for Semantic Analyzers.
Context(Configuration) - Constructor for class org.apache.hadoop.hive.ql.Context
 
Context(Configuration, String) - Constructor for class org.apache.hadoop.hive.ql.Context
Create a Context with a given executionId.
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.
conversionHelper - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
convert(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.Converter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.IdentityConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.ListConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.MapConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.StructConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.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.StringConverter
 
convert(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.TextConverter
 
CONVERTED_LOCAL_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
CONVERTED_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
converter0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
converter1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
convertIfNecessary(Object...) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ConversionHelper
 
convertIfNecessary(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Convert the return Object if necessary (when the ObjectInspectors of different possibilities are not all the same).
convertMapJoin(LinkedHashMap<Operator<? extends Serializable>, OpParseContext>, JoinOperator, QBJoinTree, int, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
convert a regular join to a a map-side join.
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.
convertSequenceFileToTextFile() - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
convertStringToPathArray(List<String>) - Static method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
convertToString(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
Convert a UTF-8 byte array to String.
convertUTF8WithBuf(byte[], char[], int, int) - Static method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
 
convertWindowsScriptToUnix(File) - Static method in class org.apache.hadoop.hive.ql.util.DosToUnix
 
copy() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
copyDirectoryToLocal(Path, Path) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
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.
copyTableJobPropertiesToConf(TableDesc, JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Copies the storage handler properties configured for a table descriptor to a runtime job configuration.
CopyTask - Class in org.apache.hadoop.hive.ql.exec
CopyTask implementation.
CopyTask() - Constructor for class org.apache.hadoop.hive.ql.exec.CopyTask
 
copyToDFSDirecory(FileSystem, Path) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
copyToStandardObject(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Returns a deep copy of the Object o that can be scanned by a StandardObjectInspector returned by getStandardObjectInspector(oi).
copyToStandardObject(Object, ObjectInspector, ObjectInspectorUtils.ObjectInspectorCopyOption) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
CopyWork - Class in org.apache.hadoop.hive.ql.plan
CopyWork.
CopyWork() - Constructor for class org.apache.hadoop.hive.ql.plan.CopyWork
 
CopyWork(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.
countAfterReport - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
counterNames - Variable in class org.apache.hadoop.hive.ql.exec.Operator
List of counter names associated with the operator.
counterNameToEnum - Variable in class org.apache.hadoop.hive.ql.exec.Operator
Each operator has its own map of its counter names to disjoint ProgressCounter - it is populated at compile time and is read in at run-time while extracting the operator specific counts.
counters - Variable in class org.apache.hadoop.hive.ql.exec.Operator
populated at runtime from hadoop counters at run time in the client.
countSel() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
countSelDi() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
CREATE - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
create(HiveConf) - Static method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
create(boolean) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBooleanObjectInspector
 
create(byte) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaByteObjectInspector
 
create(double) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDoubleObjectInspector
 
create(float) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaFloatObjectInspector
 
create(int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaIntObjectInspector
 
create(long) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaLongObjectInspector
 
create(short) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaShortObjectInspector
 
create(Text) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
create(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
create(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() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
create(int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableListObjectInspector
Create a list with the given size.
create() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableMapObjectInspector
Create an empty map.
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SettableStructObjectInspector
Create a struct which is not null, but all its fields are null.
create(int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
create() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
create_database(Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_database_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_database(Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_database_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_database(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_database(Database) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_database(Database) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_index(Index) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_role(Role, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_role(Role, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_role(Role) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_role(Role) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_role(Role) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_role(Role) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
create_role(Role) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
create_table(Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_table(Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_table(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_table(Table) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_table(Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
create_type(Type, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_type_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
create_type(Type, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_type_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
create_type(Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
create_type(Type) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
create_type(Type) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
createArrayOf(String, Object[]) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createBlob() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
createClient() - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
createClientTransport(String, String, String, String, TTransport) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Client
 
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(Database) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Create a new Database
createDatabase(Database) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
createDatabase(Database) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
createDatabase(Database) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
createDatabase(Database, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Create a database
createDatabase(Database) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Create a Database.
CreateDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
CreateDatabaseDesc.
CreateDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
For serialization only.
CreateDatabaseDesc(String, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
CreateDatabaseDesc(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
createDatabaseStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.
CreateFunctionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
For serialization only.
CreateFunctionDesc(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateFunctionDesc
 
createFunctionStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createHadoopArchive(Configuration, Path, Path, String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
createIndex(Index, Table) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
create an index
createIndex(Index, Table) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
create an index
createIndex(String, String, String, List<String>, String, boolean, String, String, String, String, String, Map<String, String>, Map<String, String>, Map<String, String>, String, String, String, String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
CreateIndexDesc - Class in org.apache.hadoop.hive.ql.plan
create index descriptor
CreateIndexDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
CreateIndexDesc(String, String, List<String>, String, boolean, String, String, String, String, String, Map<String, String>, Map<String, String>, String, Map<String, String>, String, String, String, String, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
createIndexStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
createKey() - Method in class org.apache.hadoop.hive.ql.io.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
createPool(JobConf, PathFilter...) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
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).
createRole(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
createRoleStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createRow() - Method in class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
createRow() - Method in interface org.apache.hadoop.hive.ql.exec.RecordReader
 
createRow() - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
CreateSequenceFile - Class in org.apache.hadoop.hive.serde2.thrift_test
CreateSequenceFile.
CreateSequenceFile.ThriftSerializer - Class in org.apache.hadoop.hive.serde2.thrift_test
ThriftSerializer.
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).
createServer(String, String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
createSession(HWIAuth, String) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
Here we handle creating the SessionItem, we do this for the JSP client because we need to set parameters the client is not aware of.
createSources() - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
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
 
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
CreateTableAutomaticGrant - Class in org.apache.hadoop.hive.ql.session
 
CreateTableAutomaticGrant() - Constructor for class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
CreateTableDesc - Class in org.apache.hadoop.hive.ql.plan
CreateTableDesc.
CreateTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
CreateTableDesc(String, boolean, List<FieldSchema>, List<FieldSchema>, List<String>, List<Order>, int, String, String, String, String, String, String, String, String, String, String, String, Map<String, String>, Map<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
CreateTableLikeDesc - Class in org.apache.hadoop.hive.ql.plan
CreateTableLikeDesc.
CreateTableLikeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
CreateTableLikeDesc(String, boolean, String, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
createTableStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
createTransportFactory() - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
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.BucketizedHiveRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
createValue() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
CreateViewDesc - Class in org.apache.hadoop.hive.ql.plan
CreateViewDesc.
CreateViewDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.CreateViewDesc
For serialization only.
CreateViewDesc(String, List<FieldSchema>, String, Map<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
createViewStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ctrlaCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
ctx - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
curChar - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
 
currBigKeyTag - Variable in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
currCount - Variable in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
curReader - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
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

data - Variable in class org.apache.hadoop.hive.jdbc.HiveMetaDataResultSet
 
Database - Class in org.apache.hadoop.hive.metastore.api
 
Database() - Constructor for class org.apache.hadoop.hive.metastore.api.Database
 
Database(String, String, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.Database
 
Database(Database) - Constructor for class org.apache.hadoop.hive.metastore.api.Database
Performs a deep copy on other.
Database._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
databaseComment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
databaseExists(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Query metadata to see if a database with the given name already exists.
DataCorruptErrorHeuristic - Class in org.apache.hadoop.hive.ql.exec.errors
Detects the condition where there is a error with one of the input files in the query.
DataCorruptErrorHeuristic() - Constructor for class org.apache.hadoop.hive.ql.exec.errors.DataCorruptErrorHeuristic
 
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
 
dbProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dbPropertiesList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dbVars - Static variable in class org.apache.hadoop.hive.conf.HiveConf
dbVars are the parameters can be set per database.
DCLLItem - Class in org.apache.hadoop.hive.ql.exec.persistence
Doubly circular linked list item.
DDL_TIME - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
DDLDesc - Class in org.apache.hadoop.hive.ql.plan
DDLDesc.
DDLDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DDLDesc
 
DDLSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
DDLSemanticAnalyzer.
DDLSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
ddlStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DDLTask - Class in org.apache.hadoop.hive.ql.exec
DDLTask implementation.
DDLTask() - Constructor for class org.apache.hadoop.hive.ql.exec.DDLTask
 
DDLWork - Class in org.apache.hadoop.hive.ql.plan
DDLWork.
DDLWork() - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(CreateIndexDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(AlterIndexDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DescDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DropDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, SwitchDatabaseDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterIndexDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateTableLikeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, CreateViewDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DropTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DescTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowDatabasesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowTablesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, LockTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, UnlockTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowFunctionsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowLocksDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DescFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowPartitionsDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AddPartitionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, AlterTableSimpleDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, MsckDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowTableStatusDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, DropIndexDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, RoleDDLDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, GrantDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowGrantDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, RevokeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, GrantRevokeRoleDDL) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
DDLWork(HashSet<ReadEntity>, HashSet<WriteEntity>, ShowIndexesDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.DDLWork
 
debugStream - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Debug output.
decomposePredicate(JobConf, Deserializer, ExprNodeDesc) - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler
Gives the storage handler a chance to decompose a predicate.
decompress() - Method in interface org.apache.hadoop.hive.serde2.columnar.LazyDecompressionCallback
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
deepCopy() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
deepCopy() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
deepCopy() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
deepCopy() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
deepCopy() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
deepCopy() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
deepCopy() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
deepCopy() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
deepCopy() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
deepCopy() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
DEFAULT - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
Lexical state.
DEFAULT_DATABASE_COMMENT - Static variable in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
DEFAULT_DATABASE_NAME - Static variable in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
defaultBoolVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
DefaultBucketMatcher - Class in org.apache.hadoop.hive.ql.exec
 
DefaultBucketMatcher() - Constructor for class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
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.
DefaultHiveAuthorizationProvider - Class in org.apache.hadoop.hive.ql.security.authorization
 
DefaultHiveAuthorizationProvider() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider
 
DefaultHivePartitioner<K2,V2> - Class in org.apache.hadoop.hive.ql.io
Partition keys by their Object.hashCode().
DefaultHivePartitioner() - Constructor for class org.apache.hadoop.hive.ql.io.DefaultHivePartitioner
 
defaultIntVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
defaultLongVal - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
defaultMapSeparator - Static variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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
 
DefaultSeparator - Static variable in class org.apache.hadoop.hive.serde2.TestSerDe
 
DefaultSeparators - Static variable in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
DefaultStorageHandler - Class in org.apache.hadoop.hive.ql.metadata
DefaultStorageHandler is an implementation of HiveStorageHandler which supplies the standard defaults for all options.
DefaultStorageHandler() - Constructor for class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
defaultTd - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
DefaultUDAFEvaluatorResolver - Class in org.apache.hadoop.hive.ql.exec
The default UDAF Method resolver.
DefaultUDAFEvaluatorResolver(Class<? extends UDAF>) - Constructor for class org.apache.hadoop.hive.ql.exec.DefaultUDAFEvaluatorResolver
Constructor.
DefaultUDFMethodResolver - Class in org.apache.hadoop.hive.ql.exec
The default UDF Method resolver.
DefaultUDFMethodResolver(Class<? extends UDF>) - Constructor for class org.apache.hadoop.hive.ql.exec.DefaultUDFMethodResolver
Constructor.
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_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
 
deleteDir(FileSystem, Path, boolean, Configuration) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreFsImpl
 
deleteDir(FileSystem, Path, boolean, Configuration) - Method in interface org.apache.hadoop.hive.metastore.MetaStoreFS
delete a directory
deleteDir(Path, boolean) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
deleteDirectory(File) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
DeleteResourceProcessor - Class in org.apache.hadoop.hive.ql.processors
DeleteResourceProcessor.
DeleteResourceProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor
 
deleteRow() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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
 
DelimitedJSONSerDe - Class in org.apache.hadoop.hive.serde2
DelimitedJSONSerDe.
DelimitedJSONSerDe() - Constructor for class org.apache.hadoop.hive.serde2.DelimitedJSONSerDe
 
deriveBucketMapJoinMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
deriveExplainAttributes() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
deriveExplainAttributes() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
Derive additional attributes to be rendered by EXPLAIN.
desc - Variable in class org.apache.hadoop.hive.ql.exec.ExprNodeFieldEvaluator
 
descClass - Variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory.OpTuple
 
DescDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
DescDatabaseDesc.
DescDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
DescDatabaseDesc(Path, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
descFuncNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DescFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
DescFunctionDesc.
DescFunctionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
DescFunctionDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
DescFunctionDesc(Path, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
Description - Annotation Type in org.apache.hadoop.hive.ql.exec
Description.
descStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DescTableDesc - Class in org.apache.hadoop.hive.ql.plan
DescTableDesc.
DescTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
DescTableDesc(Path, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
deserialize(RecordInput, String) - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
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 class org.apache.hadoop.hive.serde2.DelimitedJSONSerDe
Not implemented.
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(ColumnSet, String, String, String) - Static method in class org.apache.hadoop.hive.serde2.TestSerDe
 
deserialize(Writable) - Method in class org.apache.hadoop.hive.serde2.TestSerDe
 
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
 
deserializeExpression(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
deserializeMapRedLocalWork(InputStream, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
deserializeMapRedWork(InputStream, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
deserializeQueryPlan(InputStream, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Deserialize the whole query plan.
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
 
destroy() - Method in class org.apache.hadoop.hive.ql.Driver
 
destroy() - Method in class org.apache.hadoop.hive.ql.security.DummyAuthenticator
 
destroy() - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
destroy() - Method in interface org.apache.hadoop.hive.ql.security.HiveAuthenticationProvider
 
dfa20 - Variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DfsProcessor - Class in org.apache.hadoop.hive.ql.processors
DfsProcessor.
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.
dispatch(Node, Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
Dispatch the current operator.
dispatch(Node, Stack<Node>, Object...) - Method in class org.apache.hadoop.hive.ql.lib.DefaultRuleDispatcher
Dispatcher function.
dispatch(Node, Stack<Node>, Object...) - Method in interface org.apache.hadoop.hive.ql.lib.Dispatcher
Dispatcher function.
dispatch(Node, Stack<Node>, TaskGraphWalker.TaskGraphWalkerContext) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
Dispatch the current operator.
dispatch(Node, Stack<Node>) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
 
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.
displayColsUnformatted(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
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
 
distinctKeyAggrs - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
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
 
doClose() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
doClose() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
doClose() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
Close this InputSplit to future operations.
doClose() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
doesMaxRowSizeIncludeBlobs() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
doGetAliasesFromPath(Map<String, ArrayList<String>>, Map<String, Operator<? extends Serializable>>, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
Get the list of operatators from the opeerator tree that are needed for the path
doGetSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexInputFormat
 
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() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
done - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
done() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
Done() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
doNext(K, V) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
doNext(K, V) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
doNext(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
Reads the next key/value pair from the input for processing.
doNext(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
doPhase1(ASTNode, QB, SemanticAnalyzer.Phase1Ctx) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Phase 1: (including, but not limited to): 1.
doPhase1QBExpr(ASTNode, QBExpr, String, String) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
DosToUnix - Class in org.apache.hadoop.hive.ql.util
 
DosToUnix() - Constructor for class org.apache.hadoop.hive.ql.util.DosToUnix
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
DOT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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 - 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
 
dpColNames - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
dpCtx - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
dpStartCol - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
dpVals - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
dpWritables - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
Driver - Class in org.apache.hadoop.hive.ql
 
Driver(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.Driver
for backwards compatibility with current tests
Driver() - Constructor for class org.apache.hadoop.hive.ql.Driver
 
DriverContext - Class in org.apache.hadoop.hive.ql
DriverContext.
DriverContext() - Constructor for class org.apache.hadoop.hive.ql.DriverContext
 
DriverContext(Queue<Task<? extends Serializable>>, Context) - Constructor for class org.apache.hadoop.hive.ql.DriverContext
 
driverContext - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
DROP - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
drop_database(String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_database_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_database(String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_database_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_database(String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_database(String, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_database(String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_index_by_name(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_index_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_index_by_name(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_index_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_index_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_index_by_name(String, String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_index_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_partition(String, String, List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_partition(String, String, List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_partition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_partition(String, String, List<String>, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_partition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_partition_by_name(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_partition_by_name(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_partition_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_partition_by_name(String, String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_partition_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_role(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_role(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_role(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_role(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_role(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_role(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
drop_role(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
drop_table(String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_table(String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_table(String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_table(String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_table(String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
drop_type(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_type_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
drop_type(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_type_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
drop_type(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
drop_type(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
drop_type(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
dropDatabase(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropDatabase(String, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropDatabase(String, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropDatabase(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
dropDatabase(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drop a database.
dropDatabase(String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drop a database
DropDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
DropDatabaseDesc.
DropDatabaseDesc(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
dropDatabaseStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DropFunctionDesc - Class in org.apache.hadoop.hive.ql.plan
DropFunctionDesc.
DropFunctionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
For serialization only.
DropFunctionDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.DropFunctionDesc
 
dropFunctionStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropIndex(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropIndex(String, String, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropIndex(String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropIndex(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
dropIndex(String, String, String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
DropIndexDesc - Class in org.apache.hadoop.hive.ql.plan
 
DropIndexDesc(String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
dropIndexStatement() - 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, String, boolean) - 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, String, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropPartition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
dropPartition(String, List<String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropPartition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropPartitionByName(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropRole(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
dropRoleStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropTable(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropTable(String, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Deprecated. 
dropTable(String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropTable(String, String, boolean, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Drop the table.
dropTable(String, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Deprecated. As of release 0.6.0 replaced by IMetaStoreClient.dropTable(String, String, boolean, boolean). This method will be removed in release 0.7.0.
dropTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
dropTable(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
dropTable(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops table along with the data in it.
dropTable(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops table along with the data in it.
dropTable(String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Drops the table.
DropTableDesc - Class in org.apache.hadoop.hive.ql.plan
DropTableDesc.
DropTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
DropTableDesc(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
DropTableDesc(String, List<? extends Map<String, String>>) - Constructor for class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
dropTableStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
dropType(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
dropType(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
dropType(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
dropViewStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
DummyAuthenticator - Class in org.apache.hadoop.hive.ql.security
 
DummyAuthenticator() - Constructor for class org.apache.hadoop.hive.ql.security.DummyAuthenticator
 
dummyObj - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
dummyObjVectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
DummyPartition - Class in org.apache.hadoop.hive.ql.metadata
A Hive Table Partition: is a fundamental storage unit within a Table.
DummyPartition() - Constructor for class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
DummyPartition(Table, String) - Constructor for class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
DummySemanticAnalyzerHook - Class in org.apache.hadoop.hive.ql.metadata
 
DummySemanticAnalyzerHook() - Constructor for class org.apache.hadoop.hive.ql.metadata.DummySemanticAnalyzerHook
 
DummySemanticAnalyzerHook1 - Class in org.apache.hadoop.hive.ql.metadata
 
DummySemanticAnalyzerHook1() - Constructor for class org.apache.hadoop.hive.ql.metadata.DummySemanticAnalyzerHook1
 
dump(int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
dump(int, HashSet<Integer>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
dump() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
dump(String) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
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.
DynamicPartitionCtx - Class in org.apache.hadoop.hive.ql.plan
 
DynamicPartitionCtx() - Constructor for class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
DynamicPartitionCtx(Table, Map<String, String>, String, int) - Constructor for class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
DynamicPartitionCtx(DynamicPartitionCtx) - Constructor for class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
DynamicSerDe - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDe.
DynamicSerDe() - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
DynamicSerDeAsync - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeAsync(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeAsync
 
DynamicSerDeAsync(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeAsync
 
DynamicSerDeCommaOrSemicolon - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeCommaOrSemicolon(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeCommaOrSemicolon
 
DynamicSerDeCommaOrSemicolon(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeCommaOrSemicolon
 
DynamicSerDeConst - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConst(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConst
 
DynamicSerDeConst(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConst
 
DynamicSerDeConstList - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstList
 
DynamicSerDeConstList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstList
 
DynamicSerDeConstListContents - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstListContents(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstListContents
 
DynamicSerDeConstListContents(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstListContents
 
DynamicSerDeConstMap - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstMap(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstMap
 
DynamicSerDeConstMap(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstMap
 
DynamicSerDeConstMapContents - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstMapContents(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstMapContents
 
DynamicSerDeConstMapContents(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstMapContents
 
DynamicSerDeConstValue - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeConstValue(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstValue
 
DynamicSerDeConstValue(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeConstValue
 
DynamicSerDeDefinition - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeDefinition(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeDefinition
 
DynamicSerDeDefinition(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeDefinition
 
DynamicSerDeDefinitionType - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeDefinitionType(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeDefinitionType
 
DynamicSerDeDefinitionType(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeDefinitionType
 
DynamicSerDeEnum - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeEnum(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnum
 
DynamicSerDeEnum(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnum
 
DynamicSerDeEnumDef - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeEnumDef(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnumDef
 
DynamicSerDeEnumDef(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnumDef
 
DynamicSerDeEnumDefList - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeEnumDefList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnumDefList
 
DynamicSerDeEnumDefList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeEnumDefList
 
DynamicSerDeExtends - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeExtends(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeExtends
 
DynamicSerDeExtends(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeExtends
 
DynamicSerDeField - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeField.
DynamicSerDeField(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeField
 
DynamicSerDeField(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeField
 
DynamicSerDeFieldList - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeFieldList.
DynamicSerDeFieldList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
DynamicSerDeFieldList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
DynamicSerDeFieldRequiredness - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeFieldRequiredness.
DynamicSerDeFieldRequiredness(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
 
DynamicSerDeFieldRequiredness(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
 
DynamicSerDeFieldRequiredness.RequirednessTypes - Enum in org.apache.hadoop.hive.serde2.dynamic_type
RequirednessTypes.
DynamicSerDeFieldType - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeFieldType.
DynamicSerDeFieldType(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldType
 
DynamicSerDeFieldType(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldType
 
DynamicSerDeFieldValue - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeFieldValue(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldValue
 
DynamicSerDeFieldValue(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldValue
 
DynamicSerDeFlagArgs - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeFlagArgs(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFlagArgs
 
DynamicSerDeFlagArgs(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFlagArgs
 
DynamicSerDeFunction - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeFunction.
DynamicSerDeFunction(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunction
 
DynamicSerDeFunction(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunction
 
DynamicSerDeFunctionType - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeFunctionType(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunctionType
 
DynamicSerDeFunctionType(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunctionType
 
DynamicSerDeHeader - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeHeader(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeHeader
 
DynamicSerDeHeader(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeHeader
 
DynamicSerDeHeaderList - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeHeaderList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeHeaderList
 
DynamicSerDeHeaderList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeHeaderList
 
DynamicSerDeInclude - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeInclude(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeInclude
 
DynamicSerDeInclude(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeInclude
 
DynamicSerDeNamespace - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeNamespace(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeNamespace
 
DynamicSerDeNamespace(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeNamespace
 
DynamicSerDeSenum - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeSenum(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenum
 
DynamicSerDeSenum(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenum
 
DynamicSerDeSenumDef - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeSenumDef(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenumDef
 
DynamicSerDeSenumDef(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenumDef
 
DynamicSerDeSenumDefList - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeSenumDefList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenumDefList
 
DynamicSerDeSenumDefList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSenumDefList
 
DynamicSerDeService - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeService(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeService
 
DynamicSerDeService(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeService
 
DynamicSerDeSimpleNode - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeSimpleNode.
DynamicSerDeSimpleNode(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
DynamicSerDeSimpleNode(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
DynamicSerDeStart - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeStart(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStart
 
DynamicSerDeStart(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStart
 
DynamicSerDeStruct - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeStruct.
DynamicSerDeStruct(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStruct
 
DynamicSerDeStruct(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStruct
 
DynamicSerDeStructBase - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeStructBase.
DynamicSerDeStructBase(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
DynamicSerDeStructBase(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
dynamicSerDeStructBaseToObjectInspector(DynamicSerDeTypeBase) - Static method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
DynamicSerDeThrows - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeThrows(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeThrows
 
DynamicSerDeThrows(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeThrows
 
DynamicSerDeTypeBase - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeBase.
DynamicSerDeTypeBase(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
DynamicSerDeTypeBase(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBase
 
DynamicSerDeTypeBool - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeBool.
DynamicSerDeTypeBool(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
DynamicSerDeTypeBool(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeBool
 
DynamicSerDeTypeByte - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeByte.
DynamicSerDeTypeByte(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
DynamicSerDeTypeByte(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeByte
 
DynamicSerDeTypedef - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypedef.
DynamicSerDeTypedef(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
DynamicSerDeTypedef(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
DynamicSerDeTypeDefinition - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeTypeDefinition(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDefinition
 
DynamicSerDeTypeDefinition(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDefinition
 
DynamicSerDeTypeDouble - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeDouble.
DynamicSerDeTypeDouble(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
DynamicSerDeTypeDouble(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeDouble
 
DynamicSerDeTypei16 - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypei16.
DynamicSerDeTypei16(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
DynamicSerDeTypei16(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei16
 
DynamicSerDeTypei32 - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypei32.
DynamicSerDeTypei32(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
DynamicSerDeTypei32(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei32
 
DynamicSerDeTypei64 - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypei64.
DynamicSerDeTypei64(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
DynamicSerDeTypei64(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypei64
 
DynamicSerDeTypeList - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeList.
DynamicSerDeTypeList(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
DynamicSerDeTypeList(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
DynamicSerDeTypeMap - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeMap.
DynamicSerDeTypeMap(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
DynamicSerDeTypeMap(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
DynamicSerDeTypeSet - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeSet.
DynamicSerDeTypeSet(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
DynamicSerDeTypeSet(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
DynamicSerDeTypeString - Class in org.apache.hadoop.hive.serde2.dynamic_type
DynamicSerDeTypeString.
DynamicSerDeTypeString(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
DynamicSerDeTypeString(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeString
 
DynamicSerDeUnflagArgs - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeUnflagArgs(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeUnflagArgs
 
DynamicSerDeUnflagArgs(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeUnflagArgs
 
DynamicSerDeXception - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
DynamicSerDeXception(int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeXception
 
DynamicSerDeXception(thrift_grammar, int) - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeXception
 

E

elementOffset - Variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.RecordInfo
 
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.
emptyList - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
emptyList - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
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.
endFunction(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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.JoinOperator
Forward a record of join results.
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.
endScope(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
endTask(String, Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Called at the end of a task.
EnforceReadOnlyTables - Class in org.apache.hadoop.hive.ql.hooks
Implementation of a pre execute hook that prevents modifications of read-only tables used by the test framework
EnforceReadOnlyTables() - Constructor for class org.apache.hadoop.hive.ql.hooks.EnforceReadOnlyTables
 
enlargeArrays() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
Enlarge the size of arrays storing information for the elements inside the array.
ensureCapacity(int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
 
entrySet() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo
Gets the entry set on this structure.
Enum() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
EnumDef() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
EnumDefList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
ENV_PREFIX - Static variable in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
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 exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
equals(ConfigValSecurityException) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.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.HiveObjectPrivilege
 
equals(HiveObjectPrivilege) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
equals(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
equals(Index) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
equals(Object) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
equals(IndexAlreadyExistsException) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
equals(Object) - Method in 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.PrincipalPrivilegeSet
 
equals(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
equals(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
equals(PrivilegeGrantInfo) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
equals(Role) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
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_index_args
 
equals(ThriftHiveMetastore.add_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
equals(ThriftHiveMetastore.add_index_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
equals(ThriftHiveMetastore.add_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
equals(ThriftHiveMetastore.add_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
equals(ThriftHiveMetastore.alter_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
equals(ThriftHiveMetastore.alter_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
equals(ThriftHiveMetastore.alter_index_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
equals(ThriftHiveMetastore.alter_index_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
equals(ThriftHiveMetastore.alter_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
equals(ThriftHiveMetastore.alter_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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_by_name_args
 
equals(ThriftHiveMetastore.append_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
equals(ThriftHiveMetastore.append_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_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.cancel_delegation_token_args
 
equals(ThriftHiveMetastore.cancel_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
equals(ThriftHiveMetastore.cancel_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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_role_args
 
equals(ThriftHiveMetastore.create_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
equals(ThriftHiveMetastore.create_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
equals(ThriftHiveMetastore.create_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
equals(ThriftHiveMetastore.create_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_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_index_by_name_args
 
equals(ThriftHiveMetastore.drop_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
equals(ThriftHiveMetastore.drop_index_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
equals(ThriftHiveMetastore.drop_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
equals(ThriftHiveMetastore.drop_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
equals(ThriftHiveMetastore.drop_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_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_role_args
 
equals(ThriftHiveMetastore.drop_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
equals(ThriftHiveMetastore.drop_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
equals(ThriftHiveMetastore.drop_table_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
equals(ThriftHiveMetastore.drop_table_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_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_all_databases_args
 
equals(ThriftHiveMetastore.get_all_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
equals(ThriftHiveMetastore.get_all_databases_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
equals(ThriftHiveMetastore.get_all_tables_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
equals(ThriftHiveMetastore.get_all_tables_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
equals(ThriftHiveMetastore.get_config_value_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
equals(ThriftHiveMetastore.get_config_value_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
equals(ThriftHiveMetastore.get_database_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
equals(ThriftHiveMetastore.get_database_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
equals(ThriftHiveMetastore.get_databases_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
equals(ThriftHiveMetastore.get_databases_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
equals(ThriftHiveMetastore.get_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
equals(ThriftHiveMetastore.get_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
equals(ThriftHiveMetastore.get_delegation_token_with_signature_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
equals(ThriftHiveMetastore.get_delegation_token_with_signature_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_args
 
equals(ThriftHiveMetastore.get_index_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
equals(ThriftHiveMetastore.get_index_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
equals(ThriftHiveMetastore.get_index_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
equals(ThriftHiveMetastore.get_index_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
equals(ThriftHiveMetastore.get_indexes_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
equals(ThriftHiveMetastore.get_indexes_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
equals(ThriftHiveMetastore.get_partition_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
equals(ThriftHiveMetastore.get_partition_by_name_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
equals(ThriftHiveMetastore.get_partition_by_name_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
equals(ThriftHiveMetastore.get_partition_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
equals(ThriftHiveMetastore.get_partition_names_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
equals(ThriftHiveMetastore.get_partition_names_ps_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
equals(ThriftHiveMetastore.get_partition_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
equals(ThriftHiveMetastore.get_partition_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
equals(ThriftHiveMetastore.get_partition_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
equals(ThriftHiveMetastore.get_partition_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
equals(ThriftHiveMetastore.get_partitions_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
equals(ThriftHiveMetastore.get_partitions_by_filter_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
equals(ThriftHiveMetastore.get_partitions_by_filter_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
equals(ThriftHiveMetastore.get_partitions_ps_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
equals(ThriftHiveMetastore.get_partitions_ps_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
equals(ThriftHiveMetastore.get_partitions_ps_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
equals(ThriftHiveMetastore.get_partitions_ps_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
equals(ThriftHiveMetastore.get_partitions_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
equals(ThriftHiveMetastore.get_partitions_with_auth_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
equals(ThriftHiveMetastore.get_partitions_with_auth_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
equals(ThriftHiveMetastore.get_privilege_set_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
equals(ThriftHiveMetastore.get_privilege_set_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
equals(ThriftHiveMetastore.get_role_names_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
equals(ThriftHiveMetastore.get_role_names_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
equals(ThriftHiveMetastore.get_schema_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
equals(ThriftHiveMetastore.get_schema_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.ThriftHiveMetastore.grant_privileges_args
 
equals(ThriftHiveMetastore.grant_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
equals(ThriftHiveMetastore.grant_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
equals(ThriftHiveMetastore.grant_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
equals(ThriftHiveMetastore.grant_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
equals(ThriftHiveMetastore.list_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
equals(ThriftHiveMetastore.list_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
equals(ThriftHiveMetastore.list_roles_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
equals(ThriftHiveMetastore.list_roles_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
equals(ThriftHiveMetastore.partition_name_to_spec_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
equals(ThriftHiveMetastore.partition_name_to_spec_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
equals(ThriftHiveMetastore.partition_name_to_vals_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
equals(ThriftHiveMetastore.partition_name_to_vals_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
equals(ThriftHiveMetastore.renew_delegation_token_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
equals(ThriftHiveMetastore.renew_delegation_token_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
equals(ThriftHiveMetastore.revoke_privileges_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
equals(ThriftHiveMetastore.revoke_privileges_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
equals(ThriftHiveMetastore.revoke_role_args) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
equals(ThriftHiveMetastore.revoke_role_result) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
equals(Object) - Method in class org.apache.hadoop.hive.metastore.api.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.errors.ErrorAndSolution
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinKey
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
Equals function.
equals(Object) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
Equals function.
equals(Object) - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
equals(Adjacency) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
equals(Graph) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
equals(Operator) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
equals(Query) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
equals(QueryPlan) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
equals(Stage) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
equals(Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
equals(Task) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
equals(Object) - Method in class org.apache.hadoop.hive.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.serde2.typeinfo.UnionTypeInfo
 
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.getQueryPlan_args
 
equals(ThriftHive.getQueryPlan_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
equals(ThriftHive.getQueryPlan_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
equals(ThriftHive.getSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
equals(ThriftHive.getSchema_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
equals(ThriftHive.getThriftSchema_args) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
equals(Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
equals(ThriftHive.getThriftSchema_result) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
err - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
ErrorAndSolution - Class in org.apache.hadoop.hive.ql.exec.errors
Immutable class for storing a possible error and a resolution suggestion.
ErrorHeuristic - Interface in org.apache.hadoop.hive.ql.exec.errors
Classes implementing ErrorHeuristic are able to generate a possible cause and solution for Hive jobs that have failed by examining the query, task log files, and the job configuration.
ErrorMsg - Enum in org.apache.hadoop.hive.ql.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.
escapePathName(String) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
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.
eval - Variable in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
eval - Variable in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
eval(String, String, QName) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalBoolean(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalExprWithPart(ExprNodeDesc, LinkedHashMap<String, String>, StructObjectInspector) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartExprEvalUtils
Evaluate expression with partition columns
evalNode(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalNodeList(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalNumber(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evalString(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
evaluate(Object) - Method in class org.apache.hadoop.hive.ql.exec.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.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.GenericUDFArray
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArrayContains
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCase
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
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.GenericUDFField
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFHash
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIf
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIn
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.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.GenericUDFMap
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqual
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrGreaterThan
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrLessThan
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPGreaterThan
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPLessThan
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNot
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotEqual
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSentences
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStringToMap
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStruct
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestGetJavaBoolean
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestGetJavaString
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestTranslate
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnion
 
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.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) - Method in class org.apache.hadoop.hive.ql.udf.UDFAtan
 
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...) - 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.UDFDegrees
 
evaluate() - Method in class org.apache.hadoop.hive.ql.udf.UDFE
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFExp
Raise e (the base of natural logarithm) to the power of a.
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFFindInSet
 
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFFloor
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
 
evaluate(LongWritable, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
Convert UnixTime to a string format.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
Convert UnixTime to a string format.
evaluate(IntWritable, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
Convert UnixTime to a string format.
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFHex
 
evaluate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFHex
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFHex
Convert every character in s to two hex digits.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFHour
Get the hour from a date string.
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.UDFJson
Extract json object from a json string based on json path specified, and return json string of the extracted json object.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFLength
 
evaluate(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.UDFMinute
Get the minute from a date string.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFMonth
Get the month from a date string.
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(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(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() - Method in class org.apache.hadoop.hive.ql.udf.UDFPI
 
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(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRadians
 
evaluate() - Method in class org.apache.hadoop.hive.ql.udf.UDFRand
 
evaluate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRand
 
evaluate(Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFRegExp
 
evaluate(String, String, Integer) - Method in class org.apache.hadoop.hive.ql.udf.UDFRegExpExtract
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.UDFRegExpExtract
 
evaluate(Text, Text, Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFRegExpReplace
 
evaluate(Text, IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFRepeat
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFReverse
 
evaluate(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(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFSecond
Get the minute from a date string.
evaluate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFSign
Take sign of a
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(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDFTan
Take Tangent of a
evaluate(Boolean) - Method in class org.apache.hadoop.hive.ql.udf.UDFTestErrorOnFalse
 
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFTestLength
 
evaluate(String) - Method in class org.apache.hadoop.hive.ql.udf.UDFTestLength2
 
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(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFUnhex
Convert every two hex digits in s into.
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.UDFWeekOfYear
Get the week of the year from a date string.
evaluate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDFYear
Get the year from a date string.
evaluate(GenericUDF.DeferredObject[]) - Method in class org.apache.hadoop.hive.ql.udf.xml.GenericUDFXPath
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathBoolean
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathDouble
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathFloat
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathInteger
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathLong
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathShort
 
evaluate(String, String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathString
 
ExecDriver - Class in org.apache.hadoop.hive.ql.exec
ExecDriver.
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.
ExecMapper() - Constructor for class org.apache.hadoop.hive.ql.exec.ExecMapper
 
ExecMapper.reportStats - Class in org.apache.hadoop.hive.ql.exec
reportStats.
ExecMapper.reportStats(Reporter) - Constructor for class org.apache.hadoop.hive.ql.exec.ExecMapper.reportStats
 
ExecMapperContext - Class in org.apache.hadoop.hive.ql.exec
 
ExecMapperContext() - Constructor for class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
ExecReducer - Class in org.apache.hadoop.hive.ql.exec
ExecReducer.
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
Invokes executeQuery(sql) using the sql provided to the constructor.
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(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.CopyTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
Execute a query plan using Hadoop.
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.MapRedTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.Task
This method is overridden in each Task.
execute(DriverContext) - Method in class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeTask
 
execute(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
execute(String) - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Executes a query.
execute(String, AsyncMethodCallback<ThriftHive.AsyncClient.execute_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
execute(String, AsyncMethodCallback<ThriftHive.AsyncClient.execute_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
execute(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
execute(String) - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
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
 
executeClient(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
executeFromChildJVM(DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
executeImmediate(String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
Executes the SQL statement.
executeOne(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
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
Invokes executeQuery(sql) using the sql provided to the constructor.
executeQuery(String) - Method in class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
executeQuery(String) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
executeTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
This method is called in the Driver on every task.
executeUpdate() - Method in class org.apache.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
 
ExecuteWithHookContext - Interface in org.apache.hadoop.hive.ql.hooks
ExecuteWithHookContext is a new interface that the Pre/Post Execute Hook can run with the HookContext.
exists(String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
exitVal - Variable in class org.apache.hadoop.hive.ql.exec.TaskResult
 
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
Explain.
explainNoCompute() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
ExplainSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
ExplainSemanticAnalyzer.
ExplainSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.ExplainSemanticAnalyzer
 
explainStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ExplainTask - Class in org.apache.hadoop.hive.ql.exec
ExplainTask implementation.
ExplainTask() - Constructor for class org.apache.hadoop.hive.ql.exec.ExplainTask
 
ExplainTask.MethodComparator - Class in org.apache.hadoop.hive.ql.exec
MethodComparator.
ExplainTask.MethodComparator() - Constructor for class org.apache.hadoop.hive.ql.exec.ExplainTask.MethodComparator
 
ExplainWork - Class in org.apache.hadoop.hive.ql.plan
ExplainWork.
ExplainWork() - Constructor for class org.apache.hadoop.hive.ql.plan.ExplainWork
 
ExplainWork(String, 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.
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.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
 
expressions() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ExpressionTree - Class in org.apache.hadoop.hive.metastore.parser
The Class representing the filter as a binary tree.
ExpressionTree() - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree
 
ExpressionTree.ANTLRNoCaseStringStream - Class in org.apache.hadoop.hive.metastore.parser
Case insensitive ANTLR string stream
ExpressionTree.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.ANTLRNoCaseStringStream
 
ExpressionTree.LeafNode - Class in org.apache.hadoop.hive.metastore.parser
The Class representing the leaf level nodes in the ExpressionTree.
ExpressionTree.LeafNode() - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
ExpressionTree.LogicalOperator - Enum in org.apache.hadoop.hive.metastore.parser
The logical operations supported.
ExpressionTree.Operator - Enum in org.apache.hadoop.hive.metastore.parser
The operators supported.
ExpressionTree.TreeNode - Class in org.apache.hadoop.hive.metastore.parser
The Class representing a Node in the ExpressionTree.
ExpressionTree.TreeNode() - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
 
ExpressionTree.TreeNode(ExpressionTree.TreeNode, ExpressionTree.LogicalOperator, ExpressionTree.TreeNode) - Constructor for class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
 
ExprNodeColumnDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeColumnDesc.
ExprNodeColumnDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
ExprNodeColumnDesc(TypeInfo, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
ExprNodeColumnDesc(Class<?>, String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
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.
ExprNodeConstantEvaluator(ExprNodeConstantDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeConstantEvaluator
 
ExprNodeDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeDesc.
ExprNodeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
ExprNodeDesc(TypeInfo) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
ExprNodeEvaluator - Class in org.apache.hadoop.hive.ql.exec
ExprNodeEvaluator.
ExprNodeEvaluator() - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator
 
ExprNodeEvaluatorFactory - Class in org.apache.hadoop.hive.ql.exec
ExprNodeEvaluatorFactory.
ExprNodeFieldDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeFieldDesc.
ExprNodeFieldDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
ExprNodeFieldDesc(TypeInfo, ExprNodeDesc, String, Boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
ExprNodeFieldEvaluator - Class in org.apache.hadoop.hive.ql.exec
This Evaluator can evaluate s.f for s as both struct and list of struct.
ExprNodeFieldEvaluator(ExprNodeFieldDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeFieldEvaluator
 
ExprNodeGenericFuncDesc - Class in org.apache.hadoop.hive.ql.plan
Describes a GenericFunc node.
ExprNodeGenericFuncDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
ExprNodeGenericFuncDesc(TypeInfo, GenericUDF, List<ExprNodeDesc>) - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
ExprNodeGenericFuncEvaluator - Class in org.apache.hadoop.hive.ql.exec
ExprNodeGenericFuncEvaluator.
ExprNodeGenericFuncEvaluator(ExprNodeGenericFuncDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeGenericFuncEvaluator
 
ExprNodeNullDesc - Class in org.apache.hadoop.hive.ql.plan
ExprNodeNullDesc.
ExprNodeNullDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
ExprNodeNullEvaluator - Class in org.apache.hadoop.hive.ql.exec
ExprNodeNullEvaluator.
ExprNodeNullEvaluator(ExprNodeNullDesc) - Constructor for class org.apache.hadoop.hive.ql.exec.ExprNodeNullEvaluator
 
ExprProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.lineage
The processor context for the lineage information.
ExprProcCtx(LineageCtx, Operator<? extends Serializable>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcCtx
Constructor.
ExprProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.ppr
The processor context for partition pruner.
ExprProcCtx(String) - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcCtx
 
ExprProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Expression processor factory for lineage.
ExprProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
 
ExprProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Expression processor factory for partition pruning.
ExprProcFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for column expressions.
ExprProcFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.ColumnExprProcessor
 
ExprProcFactory.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.lineage
Processor for constants and null expressions.
ExprProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.DefaultExprProcessor
 
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
FieldExprProcessor.
ExprProcFactory.FieldExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory.FieldExprProcessor
 
ExprProcFactory.GenericExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for any function or field expression.
ExprProcFactory.GenericExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.GenericExprProcessor
 
ExprProcFactory.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.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
ColumnExprProcessor.
ExprWalkerProcFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.ColumnExprProcessor
 
ExprWalkerProcFactory.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
For constants and null expressions.
ExprWalkerProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.DefaultExprProcessor
 
ExprWalkerProcFactory.FieldExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
FieldExprProcessor.
ExprWalkerProcFactory.FieldExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.FieldExprProcessor
 
ExprWalkerProcFactory.GenericFuncExprProcessor - Class in org.apache.hadoop.hive.ql.ppd
If all children are candidates and refer only to one table alias then this expr is a candidate else it is not a candidate but its children could be final candidates.
ExprWalkerProcFactory.GenericFuncExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory.GenericFuncExprProcessor
 
Extends() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
ExtractDesc - Class in org.apache.hadoop.hive.ql.plan
ExtractDesc.
ExtractDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ExtractDesc
 
ExtractDesc(ExprNodeDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.ExtractDesc
 
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
 
extractPartitionSpecs(Tree) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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.
extracturl - Class in org.apache.hadoop.hive.scripts
extracturl.

F

fatalErrorCntr - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 
fatalErrorMessage(StringBuilder, long) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
fatalErrorMessage(StringBuilder, long) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
fatalErrorMessage(StringBuilder, long) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
fatalErrorMessage(StringBuilder, long) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Get the fatal error message based on counter's code.
feedSubscribers - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
fetch(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
fetch(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
fetchAll() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Fetches all the rows in a result set.
fetchAll(AsyncMethodCallback<ThriftHive.AsyncClient.fetchAll_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
fetchAll(AsyncMethodCallback<ThriftHive.AsyncClient.fetchAll_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
fetchAll() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
fetchAll() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
fetchN(int) - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Fetches numRows rows.
fetchN(int, AsyncMethodCallback<ThriftHive.AsyncClient.fetchN_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
fetchN(int, AsyncMethodCallback<ThriftHive.AsyncClient.fetchN_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
fetchN(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
fetchN(int) - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
fetchOne() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Fetches the next row in a query result set.
fetchOne(AsyncMethodCallback<ThriftHive.AsyncClient.fetchOne_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
fetchOne(AsyncMethodCallback<ThriftHive.AsyncClient.fetchOne_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
fetchOne() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
fetchOne() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
FetchOperator - Class in org.apache.hadoop.hive.ql.exec
FetchTask implementation.
FetchOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.FetchOperator
 
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.optimizer.physical.PhysicalContext
 
fetchTask - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
FetchWork - Class in org.apache.hadoop.hive.ql.plan
FetchWork.
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
 
FIELD_DELIM - Static variable in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
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
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
fieldForId(int) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
fieldForId(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
fieldForId(int) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
fieldForId(int) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
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 - 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.objectinspector.SubStructObjectInspector
 
fields - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
For a single column, a split on the secondary separator.
FieldSchema - Class in org.apache.hadoop.hive.metastore.api
 
FieldSchema() - Constructor for class org.apache.hadoop.hive.metastore.api.FieldSchema
 
FieldSchema(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.FieldSchema
 
FieldSchema(FieldSchema) - Constructor for class org.apache.hadoop.hive.metastore.api.FieldSchema
Performs a deep copy on other.
FieldSchema._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
fieldsPresent - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
FieldType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FieldValue() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FILE_INPUT_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
FILE_OUTPUT_FORMAT - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
fileFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fileName - Variable in class org.apache.hadoop.hive.cli.CliSessionState
-f option if any that the session has been invoked with.
FILENAME - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
FileSinkDesc - Class in org.apache.hadoop.hive.ql.plan
FileSinkDesc.
FileSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
FileSinkDesc(String, TableDesc, boolean, int, boolean, int, int, ArrayList<ExprNodeDesc>, DynamicPartitionCtx) - 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.FSPaths - Class in org.apache.hadoop.hive.ql.exec
 
FileSinkOperator.FSPaths() - Constructor for class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
FileSinkOperator.FSPaths(Path) - Constructor for class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
FileSinkOperator.RecordWriter - Interface in org.apache.hadoop.hive.ql.exec
RecordWriter.
FileSinkOperator.TableIdEnum - Enum in org.apache.hadoop.hive.ql.exec
TableIdEnum.
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.
FillBuff() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
FILTER_EXPR_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
FILTER_TEXT_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
FilterDesc - Class in org.apache.hadoop.hive.ql.plan
FilterDesc.
FilterDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc
 
FilterDesc(ExprNodeDesc, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc
 
FilterDesc(ExprNodeDesc, boolean, FilterDesc.sampleDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc
 
FilterDesc.sampleDesc - Class in org.apache.hadoop.hive.ql.plan
sampleDesc is used to keep track of the sampling descriptor.
FilterDesc.sampleDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
FilterDesc.sampleDesc(int, int, List<String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
FilterOperator - Class in org.apache.hadoop.hive.ql.exec
Filter operator implementation.
FilterOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.FilterOperator
 
FilterOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
Counter.
finalize() - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
 
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.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.AdjacencyType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.NodeType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.OperatorType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.StageType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.ql.plan.api.TaskType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.hadoop.hive.service.JobTrackerState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findColumn(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
findRootNonNullToken(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.ParseUtils
Performs a descent of the leftmost branch of a tree, stopping when either a node with a non-null token is found or the leaf level is encountered.
findSessionItemByName(HWIAuth, String) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
Helper method useful when you know the session name you wish to reference.
findSQLState(String) - Static method in enum org.apache.hadoop.hive.ql.parse.ErrorMsg
For a given error message string, searches for a ErrorMsg enum that appears to be a match.
findText(Text, Text, int) - Static method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils
Finds any occurence of subtext from text in the backing buffer, for avoiding string encoding and decoding.
first() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
first() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
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.
FLAG_NO_DROP - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
FLAG_OFFLINE - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
FLAG_READ_ONLY - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
FlagArgs() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
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
 
flushMemoryCacheToPersistent(File) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
Flush the main memory hash table into the persistent cache file
FOLLOW_aliasList_in_selectTrfmClause10101 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_aliasList_in_selectTrfmClause10114 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_aliasList_in_trfmClause10610 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_aliasList_in_trfmClause10623 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterDatabaseStatementSuffix_in_alterStatement2669 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterDatabaseSuffixProperties_in_alterDatabaseStatementSuffix2983 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterIndexStatementSuffix_in_alterStatement2642 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterProtectMode_in_alterStatementSuffixProtectMode4049 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterProtectModeMode_in_alterProtectMode4090 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterProtectModeMode_in_alterProtectMode4109 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatement_in_ddlStatement961 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementChangeColPosition_in_alterStatementSuffixRenameCol3236 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixAddCol_in_alterTableStatementSuffix2714 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixAddPartitions_in_alterTableStatementSuffix2738 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixArchive_in_alterTableStatementSuffix2754 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixClusterbySortby_in_alterTableStatementSuffix2794 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixDropPartitions_in_alterTableStatementSuffix2730 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixFileFormat_in_alterTblPartitionStatementSuffix3938 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixLocation_in_alterTblPartitionStatementSuffix3944 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixProperties_in_alterTableStatementSuffix2770 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixProtectMode_in_alterTblPartitionStatementSuffix3950 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixRename_in_alterTableStatementSuffix2706 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixRenameCol_in_alterTableStatementSuffix2722 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixSerdeProperties_in_alterTableStatementSuffix2778 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixTouch_in_alterTableStatementSuffix2746 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterStatementSuffixUnArchive_in_alterTableStatementSuffix2762 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterTableStatementSuffix_in_alterStatement2588 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterTblPartitionStatement_in_alterTableStatementSuffix2786 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterTblPartitionStatementSuffix_in_alterTblPartitionStatement3903 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterViewStatementSuffix_in_alterStatement2615 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_alterViewSuffixProperties_in_alterViewStatementSuffix2821 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_AMPERSAND_in_precedenceAmpersandOperator13326 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_analyzeStatement_in_ddlStatement1041 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_atomExpression_in_precedenceFieldExpression12964 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_autoRebuild_in_createIndexStatement1972 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_BITWISEOR_in_precedenceBitwiseOrOperator13377 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_BITWISEXOR_in_precedenceBitwiseXorOperator13157 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_body_in_queryStatement9018 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_booleanValue_in_constant12775 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_caseExpression_in_atomExpression12912 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_castExpression_in_atomExpression12904 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_CharSetLiteral_in_charSetStringLiteral12812 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_CharSetName_in_charSetStringLiteral12808 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_charSetStringLiteral_in_constant12767 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_body9423 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_body9558 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_regular_body9098 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_clusterByClause_in_selectStatement9261 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COLON_in_columnNameColonType8306 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_alterStatementSuffixRenameCol3225 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_colTypeList8426 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_colTypeList8431 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_columnNameColonType8308 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colType_in_columnNameType8211 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_colTypeList_in_unionType8916 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnName_in_columnNameList7822 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnName_in_columnNameList7827 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameColonType_in_columnNameColonTypeList7779 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameColonType_in_columnNameColonTypeList7784 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameColonTypeList_in_structType8818 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameComment_in_columnNameCommentList8024 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameComment_in_columnNameCommentList8029 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameCommentList_in_createViewStatement6276 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_createIndexStatement1950 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_privilegeIncludeColObject5554 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_privlegeDef5725 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameList_in_tableBuckets6601 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrder_in_columnNameOrderList7898 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrder_in_columnNameOrderList7903 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameOrderList_in_tableBuckets6614 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameType_in_columnNameTypeList7736 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameType_in_columnNameTypeList7741 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_alterStatementSuffixAddCol3135 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_createTableStatement1631 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_selectTrfmClause10105 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_selectTrfmClause10118 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_tablePartition6546 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_trfmClause10614 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnNameTypeList_in_trfmClause10627 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnRefOrder_in_orderByClause12048 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnRefOrder_in_orderByClause12058 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnRefOrder_in_sortByClause12224 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_columnRefOrder_in_sortByClause12234 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_aliasList10940 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_alterStatementSuffixDropPartitions3617 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_clusterByClause12116 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_colTypeList8429 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameColonTypeList7782 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameCommentList8027 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameList7825 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameOrderList7901 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_columnNameTypeList7739 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_dbPropertiesList1392 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_distributeByClause12172 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_expressionList10893 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_expressions13561 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_function12328 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_grantRole5336 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_groupByClause11887 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_hintArgs10402 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_hintList10249 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_indexPropertiesList2415 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_joinSource11055 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_lateralView11347 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_mapType8863 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_metastoreCheck6096 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_orderByClause12056 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_partitionSpec13815 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_principalSpecification5924 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_privilegeList5673 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_revokeRole5393 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_selectExpressionList10744 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_selectItem10500 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_selectList10020 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_sortByClause12232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_tablePropertiesList7131 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_tableSample11512 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_COMMA_in_uniqueJoinExpr11126 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_constant_in_atomExpression12888 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_constant_in_partitionVal13859 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createDatabaseStatement_in_ddlStatement921 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createFunctionStatement_in_ddlStatement1009 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createIndexStatement_in_ddlStatement1017 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createRoleStatement_in_ddlStatement1065 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createTableStatement_in_ddlStatement945 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_createViewStatement_in_ddlStatement993 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_databaseComment_in_createDatabaseStatement1268 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dbProperties_in_alterDatabaseSuffixProperties3022 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dbProperties_in_createDatabaseStatement1286 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dbPropertiesList_in_dbProperties1346 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ddlStatement_in_execStatement809 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_descFuncNames_in_descStatement4553 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_descStatement_in_ddlStatement969 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_destination_in_insertClause9693 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_body9429 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_body9564 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_regular_body9104 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_distributeByClause_in_selectStatement9267 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DIVIDE_in_hintClause10197 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DIVIDE_in_hintClause10207 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_precedenceFieldExpression12980 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_tableAllColumns10801 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_tableName11634 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_tabTypeExpr4410 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_DOT_in_viewName11693 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropDatabaseStatement_in_ddlStatement937 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropFunctionStatement_in_ddlStatement1033 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropIndexStatement_in_ddlStatement1025 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropRoleStatement_in_ddlStatement1073 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropTableStatement_in_ddlStatement953 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_dropViewStatement_in_ddlStatement1001 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EOF_in_statement720 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EOF_in_statement727 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EQUAL_in_keyValueProperty7181 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_EQUAL_in_partitionVal13857 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_execStatement_in_explainStatement757 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_execStatement_in_statement725 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_explainStatement_in_statement718 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_atomExpression12939 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_caseExpression12601 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_caseExpression12610 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_caseExpression12614 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_caseExpression12625 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_castExpression12528 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_clusterByClause12108 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_clusterByClause12118 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_columnRefOrder8124 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_distributeByClause12169 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_distributeByClause12174 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_expressionList10890 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_expressionList10895 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_expressions13558 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_expressions13563 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_function12325 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_function12330 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_groupByExpression11936 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_havingCondition12008 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_joinSource11036 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_precedenceFieldExpression12971 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_searchCondition11837 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_selectExpression10706 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_tableSample11509 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_tableSample11516 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_uniqueJoinExpr11123 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_uniqueJoinExpr11130 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_whenExpression12686 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_whenExpression12690 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expression_in_whenExpression12701 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_expressions_in_precedenceEqualExpression13502 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fileFormat_in_alterStatementSuffixFileFormat3976 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_queryStatement9008 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_regular_body9069 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromClause_in_selectStatement9232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromSource_in_joinSource11023 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromSource_in_joinSource11030 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_fromSource_in_uniqueJoinSource11090 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_function_in_atomExpression12896 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_function_in_lateralView11338 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_functionName_in_function12277 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_grantPrivileges_in_ddlStatement1081 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_grantRole_in_ddlStatement1113 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_listType8777 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_mapType8869 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_structType8820 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_GREATERTHAN_in_unionType8918 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_body9405 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_body9540 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_regular_body9080 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByClause_in_selectStatement9243 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByExpression_in_groupByClause11879 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_groupByExpression_in_groupByClause11889 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingClause_in_body9411 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingClause_in_body9546 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingClause_in_regular_body9086 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingClause_in_selectStatement9249 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_havingCondition_in_havingClause11969 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintArgName_in_hintArgs10399 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintArgName_in_hintArgs10404 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintArgs_in_hintItem10294 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintClause_in_selectClause9850 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintItem_in_hintList10246 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintItem_in_hintList10251 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintList_in_hintClause10203 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_hintName_in_hintItem10289 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_aliasList10937 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_aliasList10942 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterDatabaseSuffixProperties3016 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterIndexStatementSuffix2850 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterIndexStatementSuffix2863 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementChangeColPosition3288 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixAddCol3117 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixAddPartitions3340 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixArchive3459 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixClusterbySortby4207 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixClusterbySortby4228 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixDropPartitions3607 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixProperties3668 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixRename3066 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixRename3074 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixRenameCol3210 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixRenameCol3219 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixRenameCol3223 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixSerdeProperties3768 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixSerdeProperties3814 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixTouch3408 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterStatementSuffixUnArchive3510 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_alterViewSuffixProperties3718 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_columnName7871 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_columnNameColonType8304 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_columnNameComment8069 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_columnNameOrder7941 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_columnNameType8209 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_createDatabaseStatement1258 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_createFunctionStatement6158 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_createIndexStatement1930 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_createRoleStatement5105 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_descFuncNames14230 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_descStatement4588 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_dropDatabaseStatement1486 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_dropFunctionStatement6212 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_dropIndexStatement2464 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_dropRoleStatement5151 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_fileFormat4371 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_grantRole5333 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_grantRole5338 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_hintArgName10446 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_kwRole14261 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_kwUser14249 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_lateralView11344 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_lateralView11349 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_metastoreCheck6090 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_partitionVal13854 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_precedenceFieldExpression12983 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_principalName5966 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_principalName5984 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_principalName6002 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_privilegeIncludeColObject5547 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_privilegeObject5621 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_revokeRole5390 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_revokeRole5395 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_selectItem10487 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_selectItem10497 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_selectItem10502 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_showStatement4719 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_showStatement4783 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_showStatement4820 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_showStatement4922 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_subQuerySource11753 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_switchDatabaseStatement1436 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableAlias11400 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableFileFormat7648 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableName11632 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableName11640 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableOrColumn10851 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tablePartitionPrefix3861 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tableSource11579 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_tabTypeExpr4407 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_viewName11691 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Identifier_in_viewName11699 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_alterStatementSuffixDropPartitions3611 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropDatabaseStatement1483 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropFunctionStatement6209 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropIndexStatement2459 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropTableStatement2519 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifExists_in_dropViewStatement6417 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_alterStatementSuffixAddPartitions3344 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_createDatabaseStatement1245 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_createTableStatement1583 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_ifNotExists_in_createViewStatement6258 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexComment_in_createIndexStatement2035 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexProperties_in_alterIndexStatementSuffix2931 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexProperties_in_indexPropertiesPrefixed2334 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexPropertiesList_in_indexProperties2369 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexPropertiesPrefixed_in_createIndexStatement1981 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_indexTblName_in_createIndexStatement1990 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_inOperator_in_precedenceEqualExpression13499 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_insertClause_in_body9389 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_insertClause_in_regular_body9059 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_joinSource_in_fromClause10988 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_joinToken_in_joinSource11027 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_dbPropertiesList1389 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_dbPropertiesList1394 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_indexPropertiesList2412 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_indexPropertiesList2417 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_tablePropertiesList7128 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_keyValueProperty_in_tablePropertiesList7133 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ADD_in_alterStatementSuffixAddCol3122 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ADD_in_alterStatementSuffixAddPartitions3342 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AFTER_in_alterStatementChangeColPosition3284 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_privilegeType5776 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_queryOperator8955 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALL_in_selectClause9856 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALTER_in_alterStatement2560 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ALTER_in_privilegeType5790 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ANALYZE_in_analyzeStatement4628 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AND_in_precedenceAndOperator13642 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ARCHIVE_in_alterStatementSuffixArchive3461 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ARRAY_in_listType8771 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_castExpression12540 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_createFunctionStatement6160 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_createIndexStatement1960 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_createTableStatement1731 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_createViewStatement6304 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_lateralView11342 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_selectItem10484 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_selectItem10493 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_selectTrfmClause10094 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat7467 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat7486 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat7505 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat7524 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_tableFileFormat7644 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_AS_in_trfmClause10603 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ASC_in_columnNameOrder7946 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ASC_in_columnRefOrder8129 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BIGINT_in_primitiveType8579 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BOOLEAN_in_primitiveType8601 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BUCKET_in_tableSample11486 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BUCKETS_in_tableBuckets6626 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_clusterByClause12102 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_distributeByClause12163 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_groupByClause11873 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_orderByClause12042 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_sortByClause12218 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableBuckets6595 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableBuckets6608 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableFileFormat7589 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tablePartition6542 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatCollItemsIdentifier7305 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatFieldIdentifier7234 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatFieldIdentifier7243 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatLinesIdentifier7415 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_BY_in_tableRowFormatMapKeysIdentifier7361 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CASE_in_caseExpression12599 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CASE_in_whenExpression12675 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CAST_in_castExpression12510 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CHANGE_in_alterStatementSuffixRenameCol3212 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CLUSTER_in_clusterByClause12100 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CLUSTERED_in_alterStatementSuffixClusterbySortby4232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CLUSTERED_in_tableBuckets6593 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLLECTION_in_tableRowFormatCollItemsIdentifier7299 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMN_in_alterStatementSuffixRenameCol3214 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COLUMNS_in_alterStatementSuffixAddCol3131 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_alterStatementSuffixRenameCol3228 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_columnNameColonType8311 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_columnNameComment8072 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_columnNameType8214 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_databaseComment1528 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_indexComment2193 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMMENT_in_tableComment6499 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_COMPUTE_in_analyzeStatement4638 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createDatabaseStatement1229 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createFunctionStatement6152 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createIndexStatement1924 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createRoleStatement5099 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createTableStatement1572 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_createViewStatement6254 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_CREATE_in_privilegeType5818 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATA_in_loadStatement838 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_alterStatement2666 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_createDatabaseStatement1232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_descStatement4580 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_dropDatabaseStatement1478 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_privilegeIncludeColObject5544 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASE_in_privilegeObject5618 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATABASES_in_showStatement4679 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATE_in_primitiveType8667 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DATETIME_in_primitiveType8691 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DBPROPERTIES_in_alterDatabaseSuffixProperties3020 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DBPROPERTIES_in_createDatabaseStatement1282 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DEFERRED_in_autoRebuild2240 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DELIMITED_in_rowFormatDelimited6913 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_columnNameOrder7952 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_columnRefOrder8135 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_descStatement4500 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_descStatement4542 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESC_in_descStatement4577 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESCRIBE_in_descStatement4498 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESCRIBE_in_descStatement4540 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DESCRIBE_in_descStatement4575 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DIRECTORY_in_destination9733 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DIRECTORY_in_destination9750 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISABLE_in_alterProtectMode4107 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISTINCT_in_function12320 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISTINCT_in_selectClause9862 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DISTRIBUTE_in_distributeByClause12161 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DOUBLE_in_primitiveType8645 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_alterStatementSuffixDropPartitions3609 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropDatabaseStatement1475 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropFunctionStatement6203 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropIndexStatement2455 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropRoleStatement5145 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropTableStatement2515 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_dropViewStatement6413 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_DROP_in_privilegeType5832 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ELSE_in_caseExpression12623 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ELSE_in_whenExpression12699 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ENABLE_in_alterProtectMode4088 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_END_in_caseExpression12633 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_END_in_whenExpression12709 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ESCAPED_in_tableRowFormatFieldIdentifier7241 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXISTS_in_ifExists1150 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXISTS_in_ifNotExists1191 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXPLAIN_in_explainStatement748 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_descStatement4510 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_descStatement4547 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_descStatement4582 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_explainStatement753 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_showStatement4809 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTENDED_in_showStatement4870 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_EXTERNAL_in_createTableStatement1577 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FALSE_in_booleanValue13749 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FIELDS_in_tableRowFormatFieldIdentifier7230 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FILEFORMAT_in_alterStatementSuffixFileFormat3974 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FIRST_in_alterStatementChangeColPosition3282 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FLOAT_in_primitiveType8622 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMAT_in_rowFormatDelimited6911 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMAT_in_rowFormatSerde6842 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMATTED_in_descStatement4506 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FORMATTED_in_showStatement4899 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_fromClause10986 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_revokePrivileges5283 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_revokeRole5399 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_showStatement4712 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_showStatement4813 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FROM_in_showStatement4915 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FULL_in_joinToken11278 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_createFunctionStatement6156 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_descStatement4545 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTION_in_dropFunctionStatement6207 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_FUNCTIONS_in_showStatement4758 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_grantPrivileges5191 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_grantRole5329 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_showGrants5490 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_showRoleGrants5447 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GRANT_in_withOption6037 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GROUP_in_groupByClause11871 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_GROUP_in_principalName5982 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_HAVING_in_havingClause11967 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_HOLD_DDLTIME_in_hintName10364 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IDXPROPERTIES_in_alterIndexStatementSuffix2923 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IDXPROPERTIES_in_indexPropertiesPrefixed2331 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IF_in_ifExists1148 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IF_in_ifNotExists1187 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_indexTblName2278 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_inOperator13527 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_showStatement4714 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_showStatement4815 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IN_in_showStatement4917 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_alterStatement2639 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_createIndexStatement1926 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_dropIndexStatement2457 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_privilegeType5846 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEX_in_showStatement4904 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INDEXES_in_showStatement4906 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPATH_in_loadStatement847 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTDRIVER_in_fileFormat4323 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTDRIVER_in_tableFileFormat7539 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTFORMAT_in_fileFormat4310 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INPUTFORMAT_in_tableFileFormat7526 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INSERT_in_insertClause9689 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INT_in_primitiveType8554 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INTO_in_loadStatement862 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_INTO_in_tableBuckets6620 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_IS_in_precedenceUnarySuffixExpression13107 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ITEMS_in_tableRowFormatCollItemsIdentifier7301 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken11209 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken11246 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken11264 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken11283 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_JOIN_in_joinToken11303 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_KEYS_in_tableRowFormatMapKeysIdentifier7357 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LATERAL_in_lateralView11334 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LEFT_in_joinToken11241 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LEFT_in_joinToken11297 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_createTableStatement1601 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_showStatement4685 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_showStatement4724 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIKE_in_showStatement4824 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LIMIT_in_limitClause9803 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LINES_in_tableRowFormatLinesIdentifier7411 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOAD_in_loadStatement836 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCAL_in_destination9731 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCAL_in_loadStatement843 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_alterStatementSuffixLocation4009 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_partitionLocation3567 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCATION_in_tableLocation7696 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCK_in_lockStatement4973 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCK_in_privilegeType5860 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_LOCKS_in_showStatement4858 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_mapType8855 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_tableRowFormatMapKeysIdentifier7355 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAP_in_trfmClause10556 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MAPJOIN_in_hintName10340 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_MSCK_in_metastoreCheck6076 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NO_DROP_in_alterProtectModeMode4160 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_alterStatementSuffixClusterbySortby4230 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_ifNotExists1189 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_nullCondition13050 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NOT_in_precedenceNotOperator13593 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NULL_in_atomExpression12876 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NULL_in_nullCondition13036 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_NULL_in_nullCondition13052 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OF_in_tableSample11496 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OFFLINE_in_alterProtectModeMode4145 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_alterIndexStatementSuffix2859 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_createIndexStatement1938 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_dropIndexStatement2466 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_joinSource11033 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_privilegeIncludeColObject5537 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_privilegeObject5611 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_showStatement4909 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ON_in_tableSample11505 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OPTION_in_withOption6039 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OR_in_precedenceOrOperator13693 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ORDER_in_orderByClause12040 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUT_in_tableSample11494 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTER_in_joinToken11244 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTER_in_joinToken11262 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTER_in_joinToken11281 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTPUTDRIVER_in_fileFormat4329 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTPUTDRIVER_in_tableFileFormat7545 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTPUTFORMAT_in_fileFormat4316 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OUTPUTFORMAT_in_tableFileFormat7532 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OVERWRITE_in_insertClause9691 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_OVERWRITE_in_loadStatement858 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITION_in_partitionSpec13803 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITIONED_in_tablePartition6540 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PARTITIONS_in_showStatement4781 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_PRESERVE_in_uniqueJoinSource11087 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RCFILE_in_fileFormat4295 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RCFILE_in_tableFileFormat7507 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_READONLY_in_alterProtectModeMode4175 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REBUILD_in_alterIndexStatementSuffix2887 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REBUILD_in_autoRebuild2242 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RECORDREADER_in_recordReader6738 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RECORDWRITER_in_recordWriter6789 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REDUCE_in_trfmClause10571 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RENAME_in_alterStatementSuffixRename3068 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REPAIR_in_metastoreCheck6081 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REPLACE_in_alterStatementSuffixAddCol3128 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REVOKE_in_revokePrivileges5276 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_REVOKE_in_revokeRole5386 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_RIGHT_in_joinToken11260 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROW_in_rowFormatDelimited6909 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_ROW_in_rowFormatSerde6840 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_createDatabaseStatement1234 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMA_in_dropDatabaseStatement1480 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SCHEMAS_in_showStatement4681 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SELECT_in_privilegeType5874 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SELECT_in_selectClause9848 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SEMI_in_joinToken11300 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SEQUENCEFILE_in_fileFormat4265 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SEQUENCEFILE_in_tableFileFormat7469 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDE_in_alterStatementSuffixSerdeProperties3772 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDE_in_rowFormatSerde6844 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_alterStatementSuffixSerdeProperties3781 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_alterStatementSuffixSerdeProperties3818 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_rowFormatSerde6853 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SERDEPROPERTIES_in_tableFileFormat7607 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterDatabaseSuffixProperties3018 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterIndexStatementSuffix2921 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixFileFormat3972 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixLocation4007 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixProperties3670 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixSerdeProperties3770 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterStatementSuffixSerdeProperties3816 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SET_in_alterViewSuffixProperties3720 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_DATABASE_in_privilegeType5888 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showGrants5488 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showRoleGrants5443 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement4676 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement4706 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement4756 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement4779 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement4805 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement4856 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SHOW_in_showStatement4894 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SMALLINT_in_primitiveType8534 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SORT_in_sortByClause12216 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_SORTED_in_tableBuckets6606 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STATISTICS_in_analyzeStatement4640 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat7465 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat7484 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat7503 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat7522 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat7587 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STORED_in_tableFileFormat7642 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STREAMTABLE_in_hintName10352 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STRING_in_primitiveType8730 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_STRUCT_in_structType8814 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_alterStatement2585 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_analyzeStatement4630 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_createIndexStatement1940 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_createTableStatement1581 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_destination9767 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_dropTableStatement2517 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_indexTblName2280 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_loadStatement864 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_lockStatement4975 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_metastoreCheck6086 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_privilegeIncludeColObject5542 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_privilegeObject5616 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_showStatement4807 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLE_in_unlockStatement5055 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLES_in_showStatement4708 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TABLESAMPLE_in_tableSample11482 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TBLPROPERTIES_in_alterStatementSuffixProperties3672 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TBLPROPERTIES_in_alterViewSuffixProperties3722 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TBLPROPERTIES_in_tablePropertiesPrefixed7047 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_createFunctionStatement6154 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEMPORARY_in_dropFunctionStatement6205 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatCollItemsIdentifier7303 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatFieldIdentifier7232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatLinesIdentifier7413 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TERMINATED_in_tableRowFormatMapKeysIdentifier7359 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEXTFILE_in_fileFormat4280 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TEXTFILE_in_tableFileFormat7488 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_THEN_in_caseExpression12612 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_THEN_in_whenExpression12688 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TIMESTAMP_in_primitiveType8711 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TINYINT_in_primitiveType8513 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_alterStatementSuffixRename3070 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_grantPrivileges5213 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TO_in_grantRole5342 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TOUCH_in_alterStatementSuffixTouch3410 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TRANSFORM_in_selectClause9900 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_TRUE_in_booleanValue13744 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNARCHIVE_in_alterStatementSuffixUnArchive3512 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNION_in_queryOperator8953 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNIONTYPE_in_unionType8912 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNIQUEJOIN_in_uniqueJoinToken11177 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UNLOCK_in_unlockStatement5053 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_UPDATE_in_privilegeType5804 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_USE_in_switchDatabaseStatement1434 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_USING_in_selectTrfmClause10084 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_USING_in_trfmClause10593 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VIEW_in_alterStatement2612 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VIEW_in_createViewStatement6256 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VIEW_in_dropViewStatement6415 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_VIEW_in_lateralView11336 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WHEN_in_caseExpression12608 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WHEN_in_whenExpression12684 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WHERE_in_whereClause11796 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_alterStatementSuffixSerdeProperties3779 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_autoRebuild2238 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_createDatabaseStatement1280 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_grantPrivileges5224 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_rowFormatSerde6851 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_KW_WITH_in_tableFileFormat7605 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_kwRole_in_createRoleStatement5101 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_kwRole_in_dropRoleStatement5147 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_kwRole_in_grantRole5331 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_kwRole_in_principalName6000 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_kwRole_in_revokeRole5388 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_kwRole_in_showRoleGrants5445 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_kwUser_in_principalName5964 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lateralView_in_fromSource11448 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_listType8773 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_mapType8857 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_structType8816 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LESSTHAN_in_unionType8914 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_body9441 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_body9576 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_regular_body9116 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_limitClause_in_selectStatement9279 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_listType_in_type8467 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_loadStatement_in_execStatement801 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lockMode_in_lockStatement4982 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_lockStatement_in_ddlStatement1049 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_alterStatementSuffixAddCol3133 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_atomExpression12936 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_castExpression12516 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_createIndexStatement1946 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_createTableStatement1629 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_createViewStatement6274 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_dbProperties1344 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_expressions13556 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_function12283 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_hintItem10292 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_indexProperties2367 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_partitionSpec13810 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_privilegeIncludeColObject5550 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_privlegeDef5721 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_selectItem10495 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_selectTrfmClause10062 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_selectTrfmClause10098 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_subQuerySource11747 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableBuckets6597 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableBuckets6610 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tablePartition6544 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableProperties7083 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_tableSample11484 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_trfmClause10607 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LPAREN_in_uniqueJoinExpr11119 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_LSQUARE_in_precedenceFieldExpression12968 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_mapType_in_type8483 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_metastoreCheck_in_ddlStatement985 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_nullCondition_in_precedenceUnarySuffixExpression13109 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_constant12751 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_limitClause9807 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_tableBuckets6624 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_tableSample11491 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_Number_in_tableSample11501 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_body9417 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_body9552 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_regular_body9092 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_orderByClause_in_selectStatement9255 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionLocation_in_alterStatementSuffixAddPartitions3349 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionLocation_in_alterStatementSuffixAddPartitions3355 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterIndexStatementSuffix2872 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixAddPartitions3347 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixAddPartitions3353 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixArchive3464 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixDropPartitions3614 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixDropPartitions3619 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixTouch3413 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_alterStatementSuffixUnArchive3515 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_lockStatement4979 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_metastoreCheck6092 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_metastoreCheck6098 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_partTypeExpr4458 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_privilegeIncludeColObject5560 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_privilegeObject5623 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_showStatement4785 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_showStatement4828 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_tableOrPartition13771 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_tablePartitionPrefix3863 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionSpec_in_unlockStatement5059 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionVal_in_partitionSpec13812 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partitionVal_in_partitionSpec13818 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partTypeExpr_in_descStatement4517 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_partTypeExpr_in_showStatement4863 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_PLUS_in_hintClause10201 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAmpersandExpression_in_precedenceBitwiseOrExpression13398 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAmpersandExpression_in_precedenceBitwiseOrExpression13404 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAmpersandOperator_in_precedenceAmpersandExpression13350 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAndExpression_in_precedenceOrExpression13714 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAndExpression_in_precedenceOrExpression13720 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceAndOperator_in_precedenceAndExpression13666 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression13485 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseOrExpression_in_precedenceEqualExpression13493 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseOrOperator_in_precedenceBitwiseOrExpression13401 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseXorExpression_in_precedenceStarExpression13241 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseXorExpression_in_precedenceStarExpression13247 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceBitwiseXorOperator_in_precedenceBitwiseXorExpression13181 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceEqualExpression_in_precedenceNotExpression13620 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceEqualOperator_in_precedenceEqualExpression13490 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceFieldExpression_in_precedenceUnaryPrefixExpression13085 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceNotExpression_in_precedenceAndExpression13663 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceNotExpression_in_precedenceAndExpression13669 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceNotOperator_in_precedenceNotExpression13615 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceOrExpression_in_expression12855 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceOrOperator_in_precedenceOrExpression13717 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedencePlusExpression_in_precedenceAmpersandExpression13347 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedencePlusExpression_in_precedenceAmpersandExpression13353 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedencePlusOperator_in_precedencePlusExpression13299 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceStarExpression_in_precedencePlusExpression13296 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceStarExpression_in_precedencePlusExpression13302 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceStarOperator_in_precedenceStarExpression13244 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceUnaryOperator_in_precedenceUnaryPrefixExpression13080 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceUnaryPrefixExpression_in_precedenceUnarySuffixExpression13102 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceUnarySuffixExpression_in_precedenceBitwiseXorExpression13178 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_precedenceUnarySuffixExpression_in_precedenceBitwiseXorExpression13184 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_primitiveType_in_castExpression12552 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_primitiveType_in_mapType8861 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_primitiveType_in_type8459 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_principalSpecification5921 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_principalSpecification5926 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_showGrants5492 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalName_in_showRoleGrants5449 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalSpecification_in_grantPrivileges5215 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalSpecification_in_grantRole5344 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalSpecification_in_revokePrivileges5285 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_principalSpecification_in_revokeRole5401 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeIncludeColObject_in_showGrants5494 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeList_in_grantPrivileges5195 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeList_in_revokePrivileges5278 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeObject_in_grantPrivileges5204 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeObject_in_revokePrivileges5280 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privilegeType_in_privlegeDef5718 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privlegeDef_in_privilegeList5670 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_privlegeDef_in_privilegeList5675 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryOperator_in_queryStatementExpression8982 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatement_in_queryStatementExpression8979 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatement_in_queryStatementExpression8985 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatementExpression_in_execStatement793 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_queryStatementExpression_in_subQuerySource11749 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_recordReader_in_selectTrfmClause10134 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_recordReader_in_trfmClause10643 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_recordWriter_in_selectTrfmClause10078 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_recordWriter_in_trfmClause10587 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_regular_body_in_queryStatement9040 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_revokePrivileges_in_ddlStatement1089 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_revokeRole_in_ddlStatement1121 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormat_in_selectTrfmClause10074 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormat_in_selectTrfmClause10130 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormat_in_trfmClause10583 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormat_in_trfmClause10639 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormatDelimited_in_rowFormat6689 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormatDelimited_in_tableRowFormat6980 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormatSerde_in_rowFormat6673 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_rowFormatSerde_in_tableRowFormat7000 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_alterStatementSuffixAddCol3137 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_atomExpression12941 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_castExpression12558 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_createIndexStatement1952 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_createTableStatement1633 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_createViewStatement6278 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_dbProperties1348 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_expressions13567 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_function12348 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_hintItem10296 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_indexProperties2371 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_partitionSpec13823 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_privilegeIncludeColObject5556 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_privlegeDef5727 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_selectItem10506 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_selectTrfmClause10066 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_selectTrfmClause10108 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_subQuerySource11751 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableBuckets6603 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableBuckets6616 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tablePartition6548 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableProperties7087 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_tableSample11522 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_trfmClause10617 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RPAREN_in_uniqueJoinExpr11134 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_RSQUARE_in_precedenceFieldExpression12973 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_searchCondition_in_whereClause11798 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_body9394 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_body9529 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_regular_body9064 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectClause_in_selectStatement9227 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpression_in_selectExpressionList10741 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpression_in_selectExpressionList10746 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpression_in_selectItem10479 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpressionList_in_selectTrfmClause10064 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpressionList_in_trfmClause10561 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectExpressionList_in_trfmClause10573 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectItem_in_selectList10016 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectItem_in_selectList10023 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectList_in_selectClause9866 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectStatement_in_createTableStatement1733 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectStatement_in_createViewStatement6314 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectStatement_in_regular_body9209 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_selectTrfmClause_in_selectClause9902 - 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_lockMode0 - 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_sysFuncNames0 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_set_in_tabTypeExpr4413 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showGrants_in_ddlStatement1097 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showRoleGrants_in_ddlStatement1105 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStatement_in_ddlStatement977 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement4687 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement4726 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement4728 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement4760 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement4826 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_showStmtIdentifier_in_showStatement4911 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_body9435 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_body9570 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_regular_body9110 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sortByClause_in_selectStatement9273 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_function12304 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_hintClause10199 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_hintClause10205 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_tableAllColumns10777 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_STAR_in_tableAllColumns10803 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixLocation4013 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixRenameCol3232 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_alterStatementSuffixSerdeProperties3776 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_columnNameColonType8315 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_columnNameComment8076 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_columnNameType8218 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_constant12759 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_createFunctionStatement6162 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_createIndexStatement1964 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_databaseComment1532 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_descFuncNames14222 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_destination9735 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_destination9752 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat4314 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat4320 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat4327 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_fileFormat4333 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_indexComment2197 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_keyValueProperty7179 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_keyValueProperty7185 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_loadStatement852 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_partitionLocation3571 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_recordReader6740 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_recordWriter6791 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_rowFormatSerde6848 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_selectTrfmClause10086 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableComment6503 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat7530 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat7536 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat7543 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat7549 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableFileFormat7593 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableLocation7700 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatCollItemsIdentifier7309 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatFieldIdentifier7238 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatFieldIdentifier7247 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatLinesIdentifier7419 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_tableRowFormatMapKeysIdentifier7365 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_StringLiteral_in_trfmClause10595 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_structType_in_type8475 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_subQuerySource_in_fromSource11444 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_switchDatabaseStatement_in_ddlStatement929 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_sysFuncNames_in_descFuncNames14214 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableAlias_in_lateralView11340 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableAllColumns_in_selectExpression10710 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableBuckets_in_alterStatementSuffixClusterbySortby4209 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableBuckets_in_createTableStatement1670 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableComment_in_createTableStatement1646 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableComment_in_createViewStatement6282 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableFileFormat_in_createIndexStatement2008 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableFileFormat_in_createTableStatement1694 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableLocation_in_createIndexStatement2017 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableLocation_in_createTableStatement1616 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableLocation_in_createTableStatement1706 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_createIndexStatement1944 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_createTableStatement1588 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_createTableStatement1605 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_createViewStatement6263 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_dropIndexStatement2470 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_dropTableStatement2522 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_indexTblName2284 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_lockStatement4977 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_tableAllColumns10799 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_tableOrPartition13769 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_tableSource11567 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableName_in_unlockStatement5057 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrColumn_in_atomExpression12928 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_analyzeStatement4635 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_destination9769 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableOrPartition_in_loadStatement869 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePartition_in_createTableStatement1658 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePartitionPrefix_in_alterTblPartitionStatement3901 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixProperties3674 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixSerdeProperties3783 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterStatementSuffixSerdeProperties3820 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_alterViewSuffixProperties3724 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_rowFormatSerde6857 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_tableFileFormat7611 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableProperties_in_tablePropertiesPrefixed7050 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePropertiesList_in_tableProperties7085 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePropertiesPrefixed_in_createIndexStatement2026 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePropertiesPrefixed_in_createTableStatement1718 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tablePropertiesPrefixed_in_createViewStatement6293 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormat_in_createIndexStatement1999 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormat_in_createTableStatement1682 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatCollItemsIdentifier_in_rowFormatDelimited6918 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatFieldIdentifier_in_rowFormatDelimited6915 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatLinesIdentifier_in_rowFormatDelimited6924 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableRowFormatMapKeysIdentifier_in_rowFormatDelimited6921 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableSample_in_tableSource11572 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tableSource_in_fromSource11440 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_tabTypeExpr_in_partTypeExpr4456 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_trfmClause_in_selectClause9973 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_colType8399 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_listType8775 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_type_in_mapType8867 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_unionType_in_type8491 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_uniqueJoinExpr_in_uniqueJoinSource11092 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_uniqueJoinSource_in_joinSource11052 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_uniqueJoinSource_in_joinSource11058 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_uniqueJoinToken_in_joinSource11049 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_unlockStatement_in_ddlStatement1057 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_viewName_in_dropViewStatement6420 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whenExpression_in_atomExpression12920 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_body9399 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_body9534 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_regular_body9074 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_whereClause_in_selectStatement9237 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FOLLOW_withOption_in_grantPrivileges5226 - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
formatBinaryString(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
forward(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
 
forward(Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Passes an output row to the collector.
ForwardDesc - Class in org.apache.hadoop.hive.ql.plan
ForwardDesc.
ForwardDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ForwardDesc
 
ForwardOperator - Class in org.apache.hadoop.hive.ql.exec
Forward Operator Just forwards.
ForwardOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
forwardUDTFOutput(Object) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
forwardUDTFOutput is typically called indirectly by the GenericUDTF when the GenericUDTF has generated output rows that should be passed on to the next operator(s) in the DAG.
fromClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fromSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
fromString(String) - Static method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
 
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
 
fullyReadTest(FileSystem, int, Path) - Method in class org.apache.hadoop.hive.ql.io.TestRCFile
 
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.
FunctionInfo(boolean, String, GenericUDF) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, GenericUDAFResolver) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
FunctionInfo(boolean, String, GenericUDTF) - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
functionName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
FunctionRegistry - Class in org.apache.hadoop.hive.ql.exec
FunctionRegistry.
FunctionSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
FunctionSemanticAnalyzer.
FunctionSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.FunctionSemanticAnalyzer
 
FunctionTask - Class in org.apache.hadoop.hive.ql.exec
FunctionTask.
FunctionTask() - Constructor for class org.apache.hadoop.hive.ql.exec.FunctionTask
 
FunctionType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
FunctionWork - Class in org.apache.hadoop.hive.ql.plan
FunctionWork.
FunctionWork() - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
For serialization only.
FunctionWork(CreateFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
 
FunctionWork(DropFunctionDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.FunctionWork
 

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.
generateExecutionId() - Static method in class org.apache.hadoop.hive.ql.Context
Generate a unique executionId.
generateFileName(Byte, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateIndexBuildTaskList(Table, Index, List<Partition>, List<Partition>, Table, Set<ReadEntity>, Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
generateIndexBuildTaskList(Table, Index, List<Partition>, List<Partition>, Table, Set<ReadEntity>, Set<WriteEntity>) - Method in interface org.apache.hadoop.hive.ql.index.HiveIndexHandler
Requests that the handler generate a plan for building the index; the plan should read the base table and write out the index representation.
generateJDOFilter(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree
Generate the JDOQL filter for the given expression tree
generateJDOFilter(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
generateJDOFilter(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.TreeNode
 
generateMapJoinOperator(ParseContext, JoinOperator, QBJoinTree, int) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
generateMapMetaData() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
generateParseException() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Generate ParseException.
generatePath(String, Byte, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generatePath(Path, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateTarFileName(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateTarURI(String, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateTarURI(Path, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
generateTmpURI(String, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
Generator - Class in org.apache.hadoop.hive.ql.optimizer.lineage
This class generates the lineage information for the columns and tables from the plan before it goes through other optimization phases.
Generator() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.Generator
 
GenericUDAFAverage - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFAverage.
GenericUDAFAverage() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage
 
GenericUDAFAverage.GenericUDAFAverageEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFAverageEvaluator.
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
GenericUDAFBridgeEvaluator.
GenericUDAFBridge.GenericUDAFBridgeEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
GenericUDAFBridge.GenericUDAFBridgeEvaluator(Class<? extends UDAFEvaluator>) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
GenericUDAFCollectSet - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFCollectSet
GenericUDAFCollectSet() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCollectSet
 
GenericUDAFCollectSet.GenericUDAFMkSetEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFCollectSet.GenericUDAFMkSetEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCollectSet.GenericUDAFMkSetEvaluator
 
GenericUDAFContextNGrams - Class in org.apache.hadoop.hive.ql.udf.generic
Estimates the top-k contextual n-grams in arbitrary sequential data using a heuristic.
GenericUDAFContextNGrams() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams
 
GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
A constant-space heuristic to estimate the top-k contextual n-grams.
GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
GenericUDAFCorrelation - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the Pearson correlation coefficient corr(x, y), using the following stable one-pass method, based on: "Formulas for Robust, One-Pass Parallel Computation of Covariances and Arbitrary-Order Statistical Moments", Philippe Pebay, Sandia Labs and "The Art of Computer Programming, volume 2: Seminumerical Algorithms", Donald Knuth.
GenericUDAFCorrelation() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation
 
GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Evaluate the Pearson correlation coefficient using a stable one-pass algorithm, based on work by Philippe Pébay and Donald Knuth.
GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
GenericUDAFCount - Class in org.apache.hadoop.hive.ql.udf.generic
This class implements the COUNT aggregation function as in SQL.
GenericUDAFCount() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount
 
GenericUDAFCount.GenericUDAFCountEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFCountEvaluator.
GenericUDAFCount.GenericUDAFCountEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
GenericUDAFCovariance - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the covariance covar_pop(x, y), using the following one-pass method (ref.
GenericUDAFCovariance() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance
 
GenericUDAFCovariance.GenericUDAFCovarianceEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Evaluate the variance using the algorithm described in http://en.wikipedia.org/wiki/Algorithms_for_calculating_variance, presumably by Pébay, Philippe (2008), in "Formulas for Robust, One-Pass Parallel Computation of Covariances and Arbitrary-Order Statistical Moments", Technical Report SAND2008-6212, Sandia National Laboratories, http://infoserve.sandia.gov/sand_doc/2008/086212.pdf Incremental: n : mx_n = mx_(n-1) + [x_n - mx_(n-1)]/n : my_n = my_(n-1) + [y_n - my_(n-1)]/n : c_n = c_(n-1) + (x_n - mx_(n-1))*(y_n - my_n) : Merge: c_X = c_A + c_B + (mx_A - mx_B)*(my_A - my_B)*n_A*n_B/n_X This one-pass algorithm is stable.
GenericUDAFCovariance.GenericUDAFCovarianceEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
GenericUDAFCovarianceSample - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample covariance by extending GenericUDAFCovariance and overriding the terminate() method of the evaluator.
GenericUDAFCovarianceSample() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovarianceSample
 
GenericUDAFCovarianceSample.GenericUDAFCovarianceSampleEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample covariance by extending GenericUDAFCovarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFCovarianceSample.GenericUDAFCovarianceSampleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovarianceSample.GenericUDAFCovarianceSampleEvaluator
 
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
Mode.
GenericUDAFHistogramNumeric - Class in org.apache.hadoop.hive.ql.udf.generic
Computes an approximate histogram of a numerical column using a user-specified number of bins.
GenericUDAFHistogramNumeric() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric
 
GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Construct a histogram using an algorithm described by Ben-Haim and Tom-Tov.
GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
GenericUDAFMax - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMax() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax
 
GenericUDAFMax.GenericUDAFMaxEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMax.GenericUDAFMaxEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
GenericUDAFMin - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMin() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin
 
GenericUDAFMin.GenericUDAFMinEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFMin.GenericUDAFMinEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
GenericUDAFnGrams - Class in org.apache.hadoop.hive.ql.udf.generic
Estimates the top-k n-grams in arbitrary sequential data using a heuristic.
GenericUDAFnGrams() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams
 
GenericUDAFnGrams.GenericUDAFnGramEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
A constant-space heuristic to estimate the top-k n-grams.
GenericUDAFnGrams.GenericUDAFnGramEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
GenericUDAFParameterInfo - Interface in org.apache.hadoop.hive.ql.udf.generic
A callback interface used in conjunction with GenericUDAFResolver2 interface that allows for a more extensible and flexible means of discovering the parameter types provided for UDAF invocation.
GenericUDAFPercentileApprox - Class in org.apache.hadoop.hive.ql.udf.generic
Computes an approximate percentile (quantile) from an approximate histogram, for very large numbers of rows where the regular percentile() UDAF might run out of memory.
GenericUDAFPercentileApprox() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox
 
GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator
 
GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Construct a histogram using the algorithm described by Ben-Haim and Tom-Tov, and then use it to compute an approximate percentile value.
GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator
 
GenericUDAFResolver - Interface in org.apache.hadoop.hive.ql.udf.generic
Deprecated. Use GenericUDAFResolver2 instead.
GenericUDAFResolver2 - Interface in org.apache.hadoop.hive.ql.udf.generic
This interface extends the GenericUDAFResolver interface and provides more flexibility in terms of discovering the parameter types supplied to the UDAF.
GenericUDAFStd - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the standard deviation by extending GenericUDAFVariance and overriding the terminate() method of the evaluator.
GenericUDAFStd() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStd
 
GenericUDAFStd.GenericUDAFStdEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the standard deviation by extending GenericUDAFVarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFStd.GenericUDAFStdEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStd.GenericUDAFStdEvaluator
 
GenericUDAFStdSample - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample standard deviation by extending GenericUDAFVariance and overriding the terminate() method of the evaluator.
GenericUDAFStdSample() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample
 
GenericUDAFStdSample.GenericUDAFStdSampleEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample standard deviation by extending GenericUDAFVarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFStdSample.GenericUDAFStdSampleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFStdSample.GenericUDAFStdSampleEvaluator
 
GenericUDAFSum - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFSum.
GenericUDAFSum() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum
 
GenericUDAFSum.GenericUDAFSumDouble - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFSumDouble.
GenericUDAFSum.GenericUDAFSumDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumDouble
 
GenericUDAFSum.GenericUDAFSumLong - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDAFSumLong.
GenericUDAFSum.GenericUDAFSumLong() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumLong
 
GenericUDAFVariance - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the variance.
GenericUDAFVariance() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance
 
GenericUDAFVariance.GenericUDAFVarianceEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Evaluate the variance using the algorithm described by Chan, Golub, and LeVeque in "Algorithms for computing the sample variance: analysis and recommendations" The American Statistician, 37 (1983) pp.
GenericUDAFVariance.GenericUDAFVarianceEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
GenericUDAFVarianceSample - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample variance by extending GenericUDAFVariance and overriding the terminate() method of the evaluator.
GenericUDAFVarianceSample() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVarianceSample
 
GenericUDAFVarianceSample.GenericUDAFVarianceSampleEvaluator - Class in org.apache.hadoop.hive.ql.udf.generic
Compute the sample variance by extending GenericUDAFVarianceEvaluator and overriding the terminate() method of the evaluator.
GenericUDAFVarianceSample.GenericUDAFVarianceSampleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVarianceSample.GenericUDAFVarianceSampleEvaluator
 
GenericUDF - Class in org.apache.hadoop.hive.ql.udf.generic
A Generic User-defined function (GenericUDF) for the use with Hive.
GenericUDF() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
The constructor.
GenericUDF.DeferredObject - Interface in org.apache.hadoop.hive.ql.udf.generic
A Defered Object allows us to do lazy-evaluation and short-circuiting.
GenericUDFArray - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFArray.
GenericUDFArray() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArray
 
GenericUDFArrayContains - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFArrayContains.
GenericUDFArrayContains() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArrayContains
 
GenericUDFBaseCompare - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Base Class for operations.
GenericUDFBaseCompare() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
GenericUDFBaseCompare.CompareType - Enum in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFBridge - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFBridge encapsulates UDF to provide the same interface as GenericUDF.
GenericUDFBridge(String, boolean, Class<? extends UDF>) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
Greate a new GenericUDFBridge object.
GenericUDFBridge() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
GenericUDFCase - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for SQL construct "CASE 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
 
GenericUDFConcatWS - Class in org.apache.hadoop.hive.ql.udf.generic
Generic UDF for string function CONCAT_WS(sep,str1,str2,str3,...).
GenericUDFConcatWS() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
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
 
GenericUDFField - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFField.
GenericUDFField() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFField
 
GenericUDFHash - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for computing hash values.
GenericUDFHash() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFHash
 
GenericUDFIf - Class in org.apache.hadoop.hive.ql.udf.generic
IF(expr1,expr2,expr3)
If expr1 is TRUE (expr1 <> 0 and expr1 <> NULL) then IF() returns expr2; otherwise it returns expr3.
GenericUDFIf() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIf
 
GenericUDFIn - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFIn Example usage: SELECT key FROM src WHERE key IN ("238", "1"); From MySQL page on IN(): To comply with the SQL standard, IN returns NULL not only if the expression on the left hand side is NULL, but also if no match is found in the list and one of the expressions in the list is NULL.
GenericUDFIn() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIn
 
GenericUDFIndex - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFIndex.
GenericUDFIndex() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
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
 
GenericUDFMap - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFMap.
GenericUDFMap() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFMap
 
GenericUDFOPAnd - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for computing and.
GenericUDFOPAnd() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
GenericUDFOPEqual - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation EQUAL.
GenericUDFOPEqual() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqual
 
GenericUDFOPEqualOrGreaterThan - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation EqualOrGreaterThan.
GenericUDFOPEqualOrGreaterThan() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrGreaterThan
 
GenericUDFOPEqualOrLessThan - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation EqualOrLessThan.
GenericUDFOPEqualOrLessThan() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPEqualOrLessThan
 
GenericUDFOPGreaterThan - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation GreaterThan.
GenericUDFOPGreaterThan() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPGreaterThan
 
GenericUDFOPLessThan - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation LessThan.
GenericUDFOPLessThan() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPLessThan
 
GenericUDFOPNot - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFOPNot.
GenericUDFOPNot() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNot
 
GenericUDFOPNotEqual - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for operation Not EQUAL.
GenericUDFOPNotEqual() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotEqual
 
GenericUDFOPNotNull - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFOPNotNull.
GenericUDFOPNotNull() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
GenericUDFOPNull - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFOPNull.
GenericUDFOPNull() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
GenericUDFOPOr - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDF Class for computing or.
GenericUDFOPOr() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
GenericUDFReflect - Class in org.apache.hadoop.hive.ql.udf.generic
A simple generic udf to call java static functions via reflection.
GenericUDFReflect() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect
 
GenericUDFSentences - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFSentences: splits a natural language chunk of text into sentences and words.
GenericUDFSentences() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSentences
 
GenericUDFSize - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFSize.
GenericUDFSize() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
GenericUDFSplit - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFSplit.
GenericUDFSplit() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
GenericUDFStringToMap - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDFStringToMap.
GenericUDFStringToMap() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStringToMap
 
GenericUDFStruct - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFStruct() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStruct
 
GenericUDFTestGetJavaBoolean - Class in org.apache.hadoop.hive.ql.udf.generic
A test GenericUDF to return native Java's boolean type
GenericUDFTestGetJavaBoolean() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestGetJavaBoolean
 
GenericUDFTestGetJavaString - Class in org.apache.hadoop.hive.ql.udf.generic
A test GenericUDF to return native Java's string type
GenericUDFTestGetJavaString() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestGetJavaString
 
GenericUDFTestTranslate - Class in org.apache.hadoop.hive.ql.udf.generic
Mimics oracle's function translate(str1, str2, str3).
GenericUDFTestTranslate() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestTranslate
 
GenericUDFUnion - Class in org.apache.hadoop.hive.ql.udf.generic
 
GenericUDFUnion() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnion
 
GenericUDFUtils - Class in org.apache.hadoop.hive.ql.udf.generic
Util functions for GenericUDF classes.
GenericUDFUtils.ConversionHelper - Class in org.apache.hadoop.hive.ql.udf.generic
Convert parameters for the method if needed.
GenericUDFUtils.ConversionHelper(Method, ObjectInspector[]) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ConversionHelper
Create a PrimitiveConversionHelper for Method m.
GenericUDFUtils.ReturnObjectInspectorResolver - Class in org.apache.hadoop.hive.ql.udf.generic
This class helps to find the return ObjectInspector for a GenericUDF.
GenericUDFUtils.ReturnObjectInspectorResolver() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
 
GenericUDFUtils.ReturnObjectInspectorResolver(boolean) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
 
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
 
GenericUDFXPath - Class in org.apache.hadoop.hive.ql.udf.xml
 
GenericUDFXPath() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.GenericUDFXPath
 
GenericUDTF - Class in org.apache.hadoop.hive.ql.udf.generic
A Generic User-defined Table Generating Function (UDTF) Generates a variable number of output rows for a single input row.
GenericUDTF() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
 
GenericUDTFExplode - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDTFExplode.
GenericUDTFExplode() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
GenericUDTFJSONTuple - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDTFJSONTuple: this
GenericUDTFJSONTuple() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
GenericUDTFParseUrlTuple - Class in org.apache.hadoop.hive.ql.udf.generic
GenericUDTFParseUrlTuple: this
GenericUDTFParseUrlTuple() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
genExprNode(ASTNode, TypeCheckCtx) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
 
genExprNodeDesc(ASTNode, RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Generates an expression node descriptor for the expression passed in the arguments.
genMapJoinOpAndLocalWork(MapredWork, JoinOperator, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
GenMapRedUtils - Class in org.apache.hadoop.hive.ql.optimizer
General utility common functions for the Processor to convert operator into map-reduce tasks.
GenMapRedWalker - Class in org.apache.hadoop.hive.ql.parse
Walks the operator tree in pre order fashion.
GenMapRedWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.parse.GenMapRedWalker
constructor of the walker - the dispatcher is passed.
GenMRFileSink1 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - table scan followed by reduce sink.
GenMRFileSink1() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRFileSink1
 
GenMROperator - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - no specific rule fired.
GenMROperator() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMROperator
 
GenMRProcContext - Class in org.apache.hadoop.hive.ql.optimizer
Processor Context for creating map reduce task.
GenMRProcContext() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
GenMRProcContext(HiveConf, HashMap<Operator<? extends 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
GenMRMapJoinCtx.
GenMRProcContext.GenMRMapJoinCtx() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
GenMRProcContext.GenMRMapJoinCtx(String, TableDesc, Operator<? extends Serializable>, AbstractMapJoinOperator<? extends MapJoinDesc>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
GenMRProcContext.GenMRUnionCtx - Class in org.apache.hadoop.hive.ql.optimizer
GenMRUnionCtx.
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
 
GenMRSkewJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
GenMRSkewJoinProcessor.
GenMRTableScan1 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - table scan.
GenMRTableScan1() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRTableScan1
 
GenMRUnion1 - Class in org.apache.hadoop.hive.ql.optimizer
Processor for the rule - TableScan followed by Union.
GenMRUnion1() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GenMRUnion1
 
genPlan(QB) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
genPruner(String, ExprNodeDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
Generates the partition pruner for the expression tree.
get(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
get(String) - Method in interface org.apache.hadoop.hive.common.metrics.MetricsMBean
 
get(String) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
get() - 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(JobCloseFeedBack.FeedBackType) - Method in class org.apache.hadoop.hive.ql.exec.JobCloseFeedBack
 
get(Integer) - Static method in class org.apache.hadoop.hive.ql.exec.MapJoinMetaData
 
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(K) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
get(Class<T>, HiveConf) - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
get(T, HiveConf, Task<? extends Serializable>...) - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
get() - Static method in class org.apache.hadoop.hive.ql.io.IOContext
 
get() - Static method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
get(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(String, HiveConf) - Static method in class org.apache.hadoop.hive.ql.processors.CommandProcessorFactory
 
get() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
get the current session.
get() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDF.DeferredObject
 
get() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUtils.ReturnObjectInspectorResolver
Returns the ObjectInspector of the return value.
get(int) - Method in class org.apache.hadoop.hive.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_all_databases(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_databases_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_all_databases(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_databases_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_all_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_all_databases() - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_all_databases() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_all_tables(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_tables_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_all_tables(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_tables_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_all_tables(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_all_tables(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_all_tables(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_column_privilege_set(String, String, String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_config_value(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_config_value_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_config_value(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_config_value_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_config_value(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_config_value(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_config_value(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Returns the value of the given configuration variable name.
get_database(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_database_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_database(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_database_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_database(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_database(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_database(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_databases(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_databases_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_databases(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_databases_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_databases(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_databases(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_databases(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_db_privilege_set(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_delegation_token(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_delegation_token_with_signature(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_with_signature_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_delegation_token_with_signature(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_with_signature_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_delegation_token_with_signature(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_delegation_token_with_signature(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_delegation_token_with_signature(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_fields(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_fields(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_fields(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_fields(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_fields(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_index_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_index_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_index_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_index_by_name(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_index_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_index_names(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_names_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_index_names(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_names_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_index_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_index_names(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_index_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_indexes(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_indexes_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_indexes(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_indexes_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_indexes(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_indexes(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_indexes(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_by_name_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_by_name(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_by_name_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_by_name(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_names(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_names(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_names(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_names_ps(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_names_ps(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_names_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_names_ps(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_names_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_privilege_set(String, String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partition_with_auth(String, String, List<String>, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partition_with_auth(String, String, List<String>, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partition_with_auth(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partition_with_auth(String, String, List<String>, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partition_with_auth(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_by_filter(String, String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_by_filter(String, String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_by_filter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_by_filter(String, String, String, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_by_filter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_ps(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_ps(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_ps(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_partitions_with_auth(String, String, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_partitions_with_auth(String, String, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_partitions_with_auth(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_partitions_with_auth(String, String, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_partitions_with_auth(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_privilege_set(HiveObjectRef, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_privilege_set_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_privilege_set(HiveObjectRef, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_privilege_set_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
get_privilege_set(HiveObjectRef, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
get_privilege_set(HiveObjectType, String, String, List<String>, String, String, List<String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
get_role_names(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_names_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_role_names(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_names_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_role_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_role_names() - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_role_names() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_schema(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_schema(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_schema(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_schema(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_schema(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
Return the schema of the table.
get_table(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_table(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_table(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_table(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_table(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_table_privilege_set(String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_tables(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_tables_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_tables(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_tables_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_tables(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_tables(String, String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_tables(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_type(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_type(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_type(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_type(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_type(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_type_all(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_all_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
get_type_all(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_all_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
get_type_all(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
get_type_all(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
get_type_all(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
get_user_privilege_set(String, List<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.
getAccessTime(FileStatus) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
return the last access time of the given file.
getAddPartitionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAddTime() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getAdjacencyList() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getAdjacencyListIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getAdjacencyListSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getAdjacencyType() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getAfterCol() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getAggKey() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
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.proto.test.Complexpb.Complex
 
getAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getAlias() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getAlias() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
getAlias() - Method in class org.apache.hadoop.hive.ql.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.
getAliasBucketBaseFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
getAliasBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getAliasBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getAliasBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
getAliasBucketFiles(String, String, String) - Method in interface org.apache.hadoop.hive.ql.exec.BucketMatcher
 
getAliasBucketFiles(String, String, String) - Method in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
getAliases() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getAliasToFetchWork() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getAliasToLateralViews() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getAliasToPartnInfo() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getAliasToPath() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getAliasToTable() - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getAliasToTask() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
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.
getAllColumnsInformation(Table) - Static method in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
getAllColumnsInformation(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
getAllColumnsInformation(Index) - Static method in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
getAllDatabases() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get the names of all databases in the MetaStore.
getAllDatabases() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the names of all databases in the MetaStore.
getAllDatabases() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getAllDatabases() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getAllDatabases() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all existing database names.
getAllExprToColumnAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getAllProperties() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getAllRoleNames() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all existing role names.
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.SubStructObjectInspector
 
getAllStructFieldRefs() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
getAllStructFieldTypeInfos() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getAllTables(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get the names of all tables in the specified database.
getAllTables(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the names of all tables in the specified database.
getAllTables(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getAllTables(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getAllTables() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all table names for the current database.
getAllTables(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all table names for the specified database.
getAllUnionObjectTypeInfos() - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
getAlterDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterIndexDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterTableTypeString() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getAlterTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAlterTblSimpleDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getAndIncrementId() - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
getAndInitBackupTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getAndMakeChild(T, Operator...) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, List<Operator<? extends Serializable>>) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, RowSchema, Operator...) - Static method in class org.apache.hadoop.hive.ql.exec.OperatorFactory
Returns an operator given the conf and a list of parent operators.
getAndMakeChild(T, RowSchema, List<Operator<? extends Serializable>>) - 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
 
getArgTypeList() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
getArgumentId() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentTypeException
 
getArray(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getArray(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getArray(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getArray(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getArrayElementType(Type) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Returns the array element type, if the Type is an array (Object[]), or GenericArrayType (Map[]).
getAsciiStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getAsciiStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getAString() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getAstStringTree() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.Factory
 
getAttribute(String) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
getAttributes(String[]) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
getAttributes(String, String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getAuth() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getAuthenticator(Configuration) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getAuthenticator() - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
 
getAuthenticator() - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
getAuthenticator() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAuthorizeProviderManager(Configuration, HiveAuthenticationProvider) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getAuthorizer() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getAutoCommit() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getAuxJars() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getBackupChildrenTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getBackupTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getBase_tbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getBaseCols() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
getBaseFileName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getBaseSrc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getBaseTableName() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
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.HiveBaseResultSet
 
getBigDecimal(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBigDecimal(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBigDecimal(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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
 
getBigKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getBigKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getBigTableAlias() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getBigTableAlias() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getBin(int) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Returns a particular histogram bin.
getBinaryStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBinaryStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBlob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBlob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBlob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBlob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBoolean(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBoolean(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBoolean(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBoolean(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
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
 
getBucket(K2, V2, int) - Method in class org.apache.hadoop.hive.ql.io.DefaultHivePartitioner
Use Object.hashCode() to partition.
getBucket(K2, V2, int) - Method in interface org.apache.hadoop.hive.ql.io.HivePartitioner
Get the final bucket within a partition.
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
 
getBucketColumns() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getBucketCount() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
The number of buckets is a property of the partition.
getBucketFileNameMapping() - Method in interface org.apache.hadoop.hive.ql.exec.BucketMatcher
 
getBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
getBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getBucketFileNameMapping() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
getBucketGroup() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getBucketingDimensionId() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getBucketMapjoinContext() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getBucketMatcherClass() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
getBucketPath(int) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
mapping from bucket number to bucket path
getBufferSize() - Method in class org.apache.hadoop.hive.ql.plan.CollectDesc
 
getByte(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getByte(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getByte(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getByte(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
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.HiveBaseResultSet
 
getBytes(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getBytes(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBytes(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getBytesCopy() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
Returns a copy of the underlying bytes referenced by this instance.
getByteValue(String, String) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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 class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getCategory() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector
An ObjectInspector must inherit from one of the following interfaces if getCategory() returns: PRIMITIVE: PrimitiveObjectInspector LIST: ListObjectInspector MAP: MapObjectInspector STRUCT: StructObjectInspector.
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Return the associated category this primitive ObjectInspector.
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.PrimitiveTypeInfo
Returns the category of this TypeInfo.
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
 
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfo
The Category of this TypeInfo.
getCategory() - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
getChangedProperties() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getCharacterStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getCharacterStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getCharacterStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getCharacterStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getCheckFileFormat() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getChildErrStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getChildExprs() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getChildOperators() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getChildOutStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getChildren() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Implements the getChildren function for the Node Interface.
getChildren() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getChildren() - Method in interface org.apache.hadoop.hive.ql.lib.Node
Gets the vector of children nodes.
getChildren() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getChildren() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getChildren() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
 
getChildrenIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getChildrenSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getChildTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
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
 
getClient(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.Client.Factory
 
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.HiveBaseResultSet
 
getClob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getClob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getClob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
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(AsyncMethodCallback<ThriftHive.AsyncClient.getClusterStatus_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
getClusterStatus(AsyncMethodCallback<ThriftHive.AsyncClient.getClusterStatus_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
getClusterStatus() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getClusterStatus() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
getCmd() - Method in class org.apache.hadoop.hive.ql.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.CreateIndexDesc
 
getCollItemDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
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.Partition
 
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.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() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
getColumn(int, BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Fetch all data in the buffer for a given column.
getColumn() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
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
 
getColumnDesc() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
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
 
getColumnName() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
getColumnName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getColumnName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getColumnName() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getColumnNames(Properties) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getColumnNames(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.index.AbstractIndexHandler
 
getColumnNames(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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.
getColumnNamesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getColumnNamesFromSortCols(List<Order>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getColumnNamesOrder(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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
 
getColumnPrivilegeSet(String, String, String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getColumnPrivilegeSet(String, String, String, String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
 
getColumnProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
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(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getColumns(ASTNode, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Get the list of FieldSchema out of the ASTNode.
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
getColumns() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getColumnsHeader() - Static method in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
getColumnSize() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
getColumnType(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnTypeName(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getColumnTypes(Properties) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getColumnTypes() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getColumnTypes() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getColumnTypes() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getColumnTypesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to columnTypes.
getCombineFileInputFormat() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getCommand() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getCommandCompletor() - Static method in class org.apache.hadoop.hive.cli.CliDriver
 
getCommandType() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getComment() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
getComment() - Method in class org.apache.hadoop.hive.jdbc.JdbcTable
 
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.AlterDatabaseDesc
 
getComment() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getComment() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getComment() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
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.
getCommonJoinTask() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
getComparisonExpr() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getComparisonOp() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getCompleteName() - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
getCompleteName() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getCompleteName() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getCompleteTaskList() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getCompressCodec() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getCompressed() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
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.
getCompressType() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getConcurrency() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getConds() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getConds() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getCondsList() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getConf() - Method in class org.apache.hadoop.hive.cli.RCFileCat
 
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.Context
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator.HashTableSinkObjectCtx
 
getConf() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getConf() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
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.lockmgr.HiveLockManagerCtx
 
getConf() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getConf() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getConf() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getConf() - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
getConf() - Method in class org.apache.hadoop.hive.ql.security.DummyAuthenticator
 
getConf() - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
getConf() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getConfigValue(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getConfigValue(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
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() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getConsole() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
initialize or retrieve console object for SessionState.
getConstantDesc() - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
getContentSummary(Path, JobConf) - Method in interface org.apache.hadoop.hive.ql.io.ContentSummaryInputFormat
 
getContentSummary(Path, JobConf) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
 
getContext() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
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
 
getCounterNames() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getCounterNameToEnum() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getCounters() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getCounters() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getCounters() - Method in class org.apache.hadoop.hive.ql.exec.TaskHandle
 
getCounters() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getCpuProfile(int) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getCreateDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
getCreateIndexDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateTableGrants() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getCreateTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateTblLikeDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getCreateTime() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getCreateViewDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCreateVwDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getCrossReference(String, String, String, String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getCS(String) - Method in class org.apache.hadoop.hive.ql.Context
 
getCtx() - Method in class org.apache.hadoop.hive.ql.DriverContext
 
getCurJobNo() - Method in class org.apache.hadoop.hive.ql.DriverContext
 
getCurrAliasId() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
getCurrAliasId() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrentBigBucketFile() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
getCurrentBlockStart() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getCurrentDatabase() - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get the name of the current database
getCurrentInputFile() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
getCurrentMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getCurrentMemory() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getCurrentRow(BytesRefArrayWritable) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
get the current row used,make sure called RCFile.Reader.next(LongWritable) first.
getCurrentTask() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
getCurrentTask() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
getCurrMapJoinOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrMapJoinOp() - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
getCurrPart() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getCurrTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMapRedCtx
 
getCurrTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getCurrTbl() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getCurrTopOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.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.HiveBaseResultSet
 
getD() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
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.ql.lockmgr.HiveLockObject
 
getData() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Returns the underlying byte array.
getData() - Method in class org.apache.hadoop.hive.serde2.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() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
getDatabase(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a Database Object
getDatabase() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getDatabase() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getDatabase(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDatabase(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getDatabase(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get the database by name.
getDatabaseMajorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseMinorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
getDatabaseName() - Method in class org.apache.hadoop.hive.ql.plan.SwitchDatabaseDesc
 
getDatabaseProductName() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseProductVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getDatabaseProperties() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getDatabaseProperties() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getDatabases(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get the names of all databases in the MetaStore that match the given pattern.
getDatabases(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the names of all databases in the MetaStore that match the given pattern.
getDatabases(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDatabases(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getDatabasesByPattern(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Get all existing databases that match the given pattern.
getDataContainer() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
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.HiveBaseResultSet
 
getDate(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getDate(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getDate(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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
 
getDb() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
getDb() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
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.append_partition_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
getDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
getDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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.index.compact.IndexMetadataChangeWork
 
getDbName() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getDbName() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getDBPrivilege(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDBPrivilegeSet(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getDBPrivilegeSet(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getDDLFromFieldSchema(String, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Convert FieldSchemas to Thrift DDL.
getDecimalDigits() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
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.lineage.ExprProcFactory
 
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getDefaultExprProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.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
 
getDefaultNotificationInterval(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Gets the default notification interval to send progress updates to the tracker.
getDefaultPartitionName() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerDefaultProc class.
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
 
getDefaultProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getDefaultQueryOutputTableDesc(String, String, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
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
 
getDefaultValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
getDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getDeferredRebuild() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getDelegationToken(String, String) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Get a new delegation token.
getDelegationToken(String) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Get a new delegation token.
getDelegationToken(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getDelegationToken(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getDelegationToken(String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
getDelegationToken(String, String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
getDelegationTokenWithSignature(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getDelegationTokenWithSignature(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
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.
getDenominator() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
getDependency(LineageInfo.DataContainer, FieldSchema) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo
Gets the dependency for a table, column tuple.
getDependency(Operator<? extends Serializable>, ColumnInfo) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
Gets the dependency for an operator, columninfo tuple.
getDependentTasks() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getDependentTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
The default dependent tasks are just child tasks, but different types could implement their own (e.g.
getDesc() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getDescDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDescFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
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(Configuration, Partition, Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
getDeserializer Get the Deserializer for a partition.
getDeserializer() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getDeserializer() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getDeserializer() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
Return a deserializer object corresponding to the tableDesc.
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.PartitionDesc
 
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
 
getDestToGroupBy() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getDestToHaving() - 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
 
getDirToTaskMap() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
 
getDispatchedList() - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
getDispatchedList() - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
 
getDisplayName() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get the display name for this function.
getDisplayName() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDF
Get the String to be displayed in explain.
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArray
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArrayContains
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCase
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
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.GenericUDFField
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFHash
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIf
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIn
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.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.GenericUDFMap
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNot
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSentences
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStringToMap
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStruct
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestGetJavaBoolean
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestGetJavaString
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestTranslate
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnion
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFWhen
 
getDisplayString(String[]) - Method in class org.apache.hadoop.hive.ql.udf.xml.GenericUDFXPath
 
getDistinct() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getDistinctColumnIndices() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getDistinctFuncExprsForClause(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
 
getDone() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getDouble(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getDouble(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getDouble(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getDouble(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getDouble(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the double value out of a primitive object.
getDPColNames() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getDPCtx(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getDPCtx() - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
getDPCtx() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getDPSpecPaths() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
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
 
getDropDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDropFunctionDesc() - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
getDropIdxDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDropTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getDummyParentOp() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
getDummyParentOp() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getDumpFile() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getDynPartCtx() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getElementType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeList
 
getElementType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeSet
 
getEnd() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
 
getEndColumn() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getEndLine() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
getError() - Method in class org.apache.hadoop.hive.ql.exec.errors.ErrorAndSolution
 
getError() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getErrorAndSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.DataCorruptErrorHeuristic
 
getErrorAndSolution() - Method in interface org.apache.hadoop.hive.ql.exec.errors.ErrorHeuristic
Examine the hive query, job configuration, and the lines from the task log seen so far though processLogLine() and generate a possible cause/solution.
getErrorAndSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.MapAggrMemErrorHeuristic
 
getErrorAndSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getErrorAndSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.ScriptErrorHeuristic
 
getErrorCode() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
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
 
getErrorMessage() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getErrors() - Method in class org.apache.hadoop.hive.ql.exec.errors.TaskLogProcessor
Processes the provided task logs using the known error heuristics to get the matching errors.
getErrors() - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
getErrors() - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveParserX
 
getErrorSrcNode() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getErrRecordReaderClass() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getErrStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
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.LazyUnionObjectInspector
 
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(GenericUDAFParameterInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.AbstractGenericUDAFResolver
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCollectSet
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount
 
getEvaluator(GenericUDAFParameterInfo) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovarianceSample
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams
 
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox
 
getEvaluator(TypeInfo[]) - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFResolver
Deprecated. Get the evaluator for the parameter types.
getEvaluator(GenericUDAFParameterInfo) - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFResolver2
Get the evaluator for the parameter types.
getEvaluator(TypeInfo[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.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.getQueryPlan_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
getEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
getExcludeQueryFile() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getExecContext() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getExitVal() - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
getExpectView() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getExpectView() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getExplain() - Method in class org.apache.hadoop.hive.ql.Context
Find whether the current query is an explain query
getExportedKeys(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getExpr() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
getExprDependency(LineageCtx, Operator<? extends Serializable>, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory
Gets the expression dependencies for the expression.
getExpression(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Retrieves the ColumnInfo corresponding to a source expression which exactly matches the string rendering of the given ASTNode.
getExpressionMap() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getExpressions() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getExpressionSource(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Retrieves the source expression matching a given ASTNode's string rendering exactly.
getExprs() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the ON part's expression list.
getExprs() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getExprs() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getExprsStringMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getExprString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
getExprToColumnAlias(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getExtended() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
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
 
getFeedSubscribers() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getFetchDirection() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.HiveStatement
 
getFetchOperators() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
getFetchSize() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.HiveStatement
 
getFetchTask() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getFetchTask() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getField(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getField(int) - 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() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyUnion
Get the field out of the union.
getField(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getField(int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryStruct
Get one field out of the struct.
getField(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
Return the field based on the tag value associated with the Object.
getField(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObjectInspector
Return the field based on the tag associated with the Object.
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.CreateIndexDesc
 
getFieldDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getFieldEscape() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getFieldEscape() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
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
 
getFieldInited() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
getFieldList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFunction
 
getFieldList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStruct
 
getFieldList() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeStructBase
 
getFieldMap(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
 
getFieldName() - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
getFieldName() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
 
getFieldName() - Method in class org.apache.hadoop.hive.serde2.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
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
 
getFieldName() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
 
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.lineage.ExprProcFactory
 
getFieldProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getFieldProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.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
 
getFields() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
getFieldsAsList() - 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.
getFieldSchema() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
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(ArrayList<ColumnInfo>, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the ColumnInfo to FieldSchema.
getFieldSchemasFromColumnList(List<ExprNodeDesc>, List<String>, int, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the ColumnList to FieldSchema list.
getFieldSchemasFromColumnList(List<ExprNodeDesc>, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the ColumnList to FieldSchema list.
getFieldSchemasFromColumnListWithLength(List<ExprNodeDesc>, List<List<Integer>>, List<String>, int, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the ColumnList to FieldSchema list.
getFieldSchemasFromRowSchema(RowSchema, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Convert the RowSchema to FieldSchema list.
getFieldSchemasIterator() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getFieldSchemasSize() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getFieldSchemaString(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getFieldsFromDeserializer(String, Deserializer) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getFieldsFromDeserializer(String, Deserializer) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getFieldsIterator() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getFieldsSize() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getFieldType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeField
 
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(AlreadyExistsException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
getFieldValue(ConfigValSecurityException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
getFieldValue(Database._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getFieldValue(FieldSchema._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
getFieldValue(HiveObjectPrivilege._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getFieldValue(HiveObjectRef._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getFieldValue(Index._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getFieldValue(IndexAlreadyExistsException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
getFieldValue(InvalidObjectException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
getFieldValue(InvalidOperationException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
getFieldValue(MetaException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
getFieldValue(NoSuchObjectException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
getFieldValue(Order._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
getFieldValue(Partition._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getFieldValue(PrincipalPrivilegeSet._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getFieldValue(PrivilegeBag._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
getFieldValue(PrivilegeGrantInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getFieldValue(Role._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
getFieldValue(Schema._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
getFieldValue(SerDeInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getFieldValue(StorageDescriptor._Fields) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getFieldValue(Table._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getFieldValue(ThriftHiveMetastore.add_index_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
getFieldValue(ThriftHiveMetastore.add_index_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
getFieldValue(ThriftHiveMetastore.add_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
getFieldValue(ThriftHiveMetastore.add_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getFieldValue(ThriftHiveMetastore.alter_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
getFieldValue(ThriftHiveMetastore.alter_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
getFieldValue(ThriftHiveMetastore.alter_index_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getFieldValue(ThriftHiveMetastore.alter_index_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
getFieldValue(ThriftHiveMetastore.alter_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
getFieldValue(ThriftHiveMetastore.alter_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
getFieldValue(ThriftHiveMetastore.alter_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
getFieldValue(ThriftHiveMetastore.alter_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
getFieldValue(ThriftHiveMetastore.append_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getFieldValue(ThriftHiveMetastore.append_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
getFieldValue(ThriftHiveMetastore.append_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
getFieldValue(ThriftHiveMetastore.append_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
getFieldValue(ThriftHiveMetastore.cancel_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
getFieldValue(ThriftHiveMetastore.cancel_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
getFieldValue(ThriftHiveMetastore.create_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
getFieldValue(ThriftHiveMetastore.create_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
getFieldValue(ThriftHiveMetastore.create_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
getFieldValue(ThriftHiveMetastore.create_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
getFieldValue(ThriftHiveMetastore.create_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
getFieldValue(ThriftHiveMetastore.create_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getFieldValue(ThriftHiveMetastore.create_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
getFieldValue(ThriftHiveMetastore.create_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
getFieldValue(ThriftHiveMetastore.drop_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
getFieldValue(ThriftHiveMetastore.drop_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
getFieldValue(ThriftHiveMetastore.drop_index_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
getFieldValue(ThriftHiveMetastore.drop_index_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
getFieldValue(ThriftHiveMetastore.drop_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getFieldValue(ThriftHiveMetastore.drop_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
getFieldValue(ThriftHiveMetastore.drop_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
getFieldValue(ThriftHiveMetastore.drop_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
getFieldValue(ThriftHiveMetastore.drop_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
getFieldValue(ThriftHiveMetastore.drop_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
getFieldValue(ThriftHiveMetastore.drop_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
getFieldValue(ThriftHiveMetastore.drop_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
getFieldValue(ThriftHiveMetastore.drop_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
getFieldValue(ThriftHiveMetastore.drop_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
getFieldValue(ThriftHiveMetastore.get_all_databases_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
getFieldValue(ThriftHiveMetastore.get_all_databases_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getFieldValue(ThriftHiveMetastore.get_all_tables_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
getFieldValue(ThriftHiveMetastore.get_all_tables_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getFieldValue(ThriftHiveMetastore.get_config_value_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
getFieldValue(ThriftHiveMetastore.get_config_value_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
getFieldValue(ThriftHiveMetastore.get_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
getFieldValue(ThriftHiveMetastore.get_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
getFieldValue(ThriftHiveMetastore.get_databases_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
getFieldValue(ThriftHiveMetastore.get_databases_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getFieldValue(ThriftHiveMetastore.get_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
getFieldValue(ThriftHiveMetastore.get_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
getFieldValue(ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
getFieldValue(ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
getFieldValue(ThriftHiveMetastore.get_fields_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
getFieldValue(ThriftHiveMetastore.get_fields_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getFieldValue(ThriftHiveMetastore.get_index_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
getFieldValue(ThriftHiveMetastore.get_index_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
getFieldValue(ThriftHiveMetastore.get_index_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
getFieldValue(ThriftHiveMetastore.get_index_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getFieldValue(ThriftHiveMetastore.get_indexes_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
getFieldValue(ThriftHiveMetastore.get_indexes_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getFieldValue(ThriftHiveMetastore.get_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getFieldValue(ThriftHiveMetastore.get_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
getFieldValue(ThriftHiveMetastore.get_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
getFieldValue(ThriftHiveMetastore.get_partition_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getFieldValue(ThriftHiveMetastore.get_partition_names_ps_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getFieldValue(ThriftHiveMetastore.get_partition_names_ps_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getFieldValue(ThriftHiveMetastore.get_partition_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getFieldValue(ThriftHiveMetastore.get_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getFieldValue(ThriftHiveMetastore.get_partition_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getFieldValue(ThriftHiveMetastore.get_partition_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_by_filter_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_by_filter_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_ps_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_ps_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getFieldValue(ThriftHiveMetastore.get_partitions_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getFieldValue(ThriftHiveMetastore.get_partitions_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getFieldValue(ThriftHiveMetastore.get_privilege_set_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getFieldValue(ThriftHiveMetastore.get_privilege_set_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
getFieldValue(ThriftHiveMetastore.get_role_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
getFieldValue(ThriftHiveMetastore.get_role_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getFieldValue(ThriftHiveMetastore.get_schema_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
getFieldValue(ThriftHiveMetastore.get_schema_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getFieldValue(ThriftHiveMetastore.get_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
getFieldValue(ThriftHiveMetastore.get_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
getFieldValue(ThriftHiveMetastore.get_tables_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
getFieldValue(ThriftHiveMetastore.get_tables_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getFieldValue(ThriftHiveMetastore.get_type_all_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
getFieldValue(ThriftHiveMetastore.get_type_all_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
getFieldValue(ThriftHiveMetastore.get_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
getFieldValue(ThriftHiveMetastore.get_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
getFieldValue(ThriftHiveMetastore.grant_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
getFieldValue(ThriftHiveMetastore.grant_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
getFieldValue(ThriftHiveMetastore.grant_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getFieldValue(ThriftHiveMetastore.grant_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
getFieldValue(ThriftHiveMetastore.list_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
getFieldValue(ThriftHiveMetastore.list_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getFieldValue(ThriftHiveMetastore.list_roles_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
getFieldValue(ThriftHiveMetastore.list_roles_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getFieldValue(ThriftHiveMetastore.partition_name_to_spec_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
getFieldValue(ThriftHiveMetastore.partition_name_to_spec_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
getFieldValue(ThriftHiveMetastore.partition_name_to_vals_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
getFieldValue(ThriftHiveMetastore.partition_name_to_vals_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getFieldValue(ThriftHiveMetastore.renew_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
getFieldValue(ThriftHiveMetastore.renew_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
getFieldValue(ThriftHiveMetastore.revoke_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
getFieldValue(ThriftHiveMetastore.revoke_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
getFieldValue(ThriftHiveMetastore.revoke_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
getFieldValue(ThriftHiveMetastore.revoke_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
getFieldValue(Type._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getFieldValue(UnknownDBException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
getFieldValue(UnknownTableException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
getFieldValue(Version._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
getFieldValue(Adjacency._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getFieldValue(Graph._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getFieldValue(Operator._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getFieldValue(Query._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getFieldValue(QueryPlan._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
getFieldValue(Stage._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getFieldValue(Task._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getFieldValue(InnerStruct._Fields) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
getFieldValue(ThriftTestObj._Fields) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
getFieldValue(Complex._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getFieldValue(IntString._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getFieldValue(HiveClusterStatus._Fields) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getFieldValue(HiveServerException._Fields) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
getFieldValue(ThriftHive.execute_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
getFieldValue(ThriftHive.execute_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
getFieldValue(ThriftHive.fetchAll_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
getFieldValue(ThriftHive.fetchAll_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getFieldValue(ThriftHive.fetchN_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
getFieldValue(ThriftHive.fetchN_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
getFieldValue(ThriftHive.fetchOne_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
getFieldValue(ThriftHive.fetchOne_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
getFieldValue(ThriftHive.getClusterStatus_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
getFieldValue(ThriftHive.getClusterStatus_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
getFieldValue(ThriftHive.getQueryPlan_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
getFieldValue(ThriftHive.getQueryPlan_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
getFieldValue(ThriftHive.getSchema_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
getFieldValue(ThriftHive.getSchema_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
getFieldValue(ThriftHive.getThriftSchema_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
getFieldValue(ThriftHive.getThriftSchema_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
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.
getFileId() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
getFileStatusRecurse(Path, int, FileSystem) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get all file status from a root path and recursively go deep into certain levels.
getFileSystem() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.MiniDFSShim
 
getFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getFilterExpr() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerFilterProc class.
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpProcFactory
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
 
getFilterProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getFilters() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getFilters() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getFilters() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getFiltersForPushing() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getFiltersStringMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
Get the string representation of filters.
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.
getFinalPath(String) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
Update the final paths according to tmpPath.
getFinalPath(String, Path, String) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
Update the final paths according to tmpPath.
getFirst() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getFloat(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getFloat(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getFloat(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getFloat(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
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 functions 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
getFullDPSpecs(Configuration, DynamicPartitionCtx) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Construct a list of full partition spec from Dynamic Partition Context and the directory names corresponding to these dynamic partitions.
getFuncExprNodeDesc(String, 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).
getFunctionClass() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get the Class of the UDF.
getFunctionClass() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
getFunctionColumns(String, String, String, String) - Method in class org.apache.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
 
getFunctionSynonyms(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns the set of synonyms of the supplied function.
getFunctionText(ASTNode, boolean) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
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.lineage.ExprProcFactory
 
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcFactory
 
getGenericFuncProcessor() - Static method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerProcFactory
 
getGenericUDAFEvaluator(String, List<TypeInfo>, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Get the GenericUDAF evaluator for the name and argumentClasses.
getGenericUDAFEvaluator() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getGenericUDAFName() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getGenericUDAFResolver() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get the GenericUDAFResolver object for the function.
getGenericUDAFResolver(String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
getGenericUDF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get a new GenericUDF object for the function.
getGenericUDF() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
getGenericUDFForAnd() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
A shortcut to get the "and" GenericUDF.
getGenericUDFForIndex() - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
A shortcut to get the "index" GenericUDF.
getGenericUDTF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Get a new GenericUDTF object for the function.
getGenericUDTF() - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
getGrammarFileName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getGrant() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getGrantDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getGrantInfo() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getGrantOption() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getGrantor() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getGrantor() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getGrantorType() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getGrantorType() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getGrantRevokeRoleDDL() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getGroup() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getGroup_namesIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getGroup_namesSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getGroupByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getGroupByMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerGroupByProc class.
getGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getGroupByProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory
 
getGroupGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
getGroupKeyNotReductionKey() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getGroupKeyObject() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getGroupNames() - Method in class org.apache.hadoop.hive.ql.security.DummyAuthenticator
 
getGroupNames() - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
getGroupNames() - Method in interface org.apache.hadoop.hive.ql.security.HiveAuthenticationProvider
 
getGroupOpToInputTables() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getGroupPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getGroupPrivilegesSize() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getGroups() - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
getHadoopShims() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
Factory method to get an instance of HadoopShims based on the version of Hadoop on the classpath.
getHadoopSupportsSplittable() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getHadoopThriftAuthBridge() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
 
getHadoopVersion() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getHandlerClsName() - Method in enum org.apache.hadoop.hive.ql.index.HiveIndex.IndexType
 
getHandleSkewJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getHashtableMemoryUsage() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
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.
getHavingForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
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
 
getHive() - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContext
 
getHive() - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
getHiveConf() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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.
getHiveJobID(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getHiveLockMgr() - Method in class org.apache.hadoop.hive.ql.Context
 
getHiveLockMode() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLock
 
getHiveLockMode() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
getHiveLockObject() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLock
 
getHiveLockObject() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
getHiveLocks() - Method in class org.apache.hadoop.hive.ql.Context
 
getHiveObj() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
getHiveOperation() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveBinaryOutputFormat
create the final out file, and output row by row.
getHiveRecordWriter(JobConf, TableDesc, Class<? extends Writable>, FileSinkDesc, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
create the final out file, and output row by row.
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveNullValueSequenceFileOutputFormat
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in interface org.apache.hadoop.hive.ql.io.HiveOutputFormat
create the final out file and get some specific settings.
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class org.apache.hadoop.hive.ql.io.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.HiveBaseResultSet
 
getHoldability() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getHoldDDLTime() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getHook(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHookLoader
Loads a hook for the specified table.
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
 
getIdToTableNameMap() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getIdx_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getIdxProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIfExists() - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getIfNotExists() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
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
 
getIndex(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getIndex(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getIndex(String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getIndex(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getIndex(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getIndex(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getIndex(String, String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getIndex() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx
Gets the dependency index.
getIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
getIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
getIndex_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
getIndexColumnsHeader() - Static method in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
getIndexComment() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIndexedCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIndexes(String, String, int) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getIndexes(String, String, int) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getIndexes(String, String, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getIndexHandler(HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getIndexHandlerClass() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getIndexHandlerClass() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getIndexInfo(String, String, String, boolean, boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getIndexName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getIndexName() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getIndexName() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getIndexName() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIndexName() - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
getIndexTable() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getIndexTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getIndexTableName(String, String, String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getIndexTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getIndexTbl() - Method in class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeWork
 
getIndexType(String) - Static method in class org.apache.hadoop.hive.ql.index.HiveIndex
 
getIndexTypeByClassName(String) - Static method in class org.apache.hadoop.hive.ql.index.HiveIndex
 
getIndexTypeHandlerClass() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getInput() - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
getInputColumnLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInputDBLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInputFile() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getInputFileChangeSensitive() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getInputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getInputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getInputFileFormatClassName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getInputFileFormatClassName() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getInputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getInputFormat() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getInputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getInputformat() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getInputFormatChecker(Class<?>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
get an InputFormatChecker for a file format.
getInputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getInputFormatClass() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getInputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getInputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getInputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getInputFormatClassName() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
 
getInputFormatFromCache(Class, JobConf) - Static method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getInputObjInspectors() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getInputOperator() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcCtx
Gets the input operator.
getInputPathsShim(JobConf) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
getInputPruning() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the flag that indicates whether input pruning is possible.
getInputPruning() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
getInputRequiredPrivileges() - Method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
 
getInputRR() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
getInputs() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getInputs() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
Get the input set.
getInputs() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getInputs() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getInputs() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getInputs() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getInputSplit() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getInputSplitShim() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
getInputSplitShim() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
getInputSummary(Context, MapredWork, PathFilter) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Calculate the total size of input files.
getInputTableLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInputTableList() - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
getInputToDPCols() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getInputUserLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getInRecordWriterClass() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getInspector() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
getInstance(List<String>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.MetadataListStructObjectInspector
 
getInt(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getInt(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getInt(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getInt(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
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
 
getInvRslvMap() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getIOContext() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
getIoCxt() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
getIOExceptions() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getIsDfsDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getIsDfsDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getIsExprResolver() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getIsHidden() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getIsList() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
getIsPartitionColOrVirtualCol() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
getIsQuery() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getIsSamplingPred() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
getIsSilent() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getIsSilent() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getIsSubQ() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getIsVerbose() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getIsVirtualCol() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getItems() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
getItemSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
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().
getJc() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
getJDBCMajorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getJDBCMinorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getJdoConnectionUrl(Configuration) - Method in interface org.apache.hadoop.hive.metastore.hooks.JDOConnectionURLHook
Gets the connection URL to supply to JDO.
getJdoOp() - Method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
 
getJettyShims() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
Factory method to get an instance of JettyShims based on the version of Hadoop on the classpath.
getJob() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
getJob() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
 
getJobEndMsg(String) - Static method in class org.apache.hadoop.hive.ql.exec.ExecDriver
this msg pattern is used to track when a job is successfully done.
getJobId() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
getJobInfoMap() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getJobProperties() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
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.JoinCondDesc
 
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.optimizer.lineage.OpProcFactory
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory
 
getJoinProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getJoinPrunedColLists() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getJoinSrc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getJoinStreamDesc() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getJoinTree() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getJoinType() - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
getJSONKeyValue(Object, Object) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getJSONMap(Map) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getJSONQuery(Query) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getJSONString(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
getJSONValue(Object) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
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.HashTableSinkDesc
 
getKeys() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getKeySerializeInfo() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getKeySize() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getKeyTableDesc() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getKeyTableDesc() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getKeyTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getKeyTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getKeyType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
getKeyValueSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyMapObjectInspector
 
getKeywords() - Static method in class org.apache.hadoop.hive.ql.parse.ParseDriver
 
getKeyWrapper() - Method in class org.apache.hadoop.hive.ql.exec.KeyWrapperFactory
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getLastAccessTime() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getLastColumnTakesRest() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getLastInputFile() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
getLateralViewJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
 
getLateralViewJoinProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getLateralViewsForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
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
 
getLazyUnionObjectInspector(List<ObjectInspector>, byte, Text, boolean, byte) - Static method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyObjectInspectorFactory
 
getLeft() - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
getLeft() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getLeftAlias() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
returns left alias if any - this is used for merging later on.
getLeftAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getLength() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
getLength() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
 
getLength() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getLength(int) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getLength() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
getLength(int) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the length of the ith Path.
getLength() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getLength() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Returns the length of the input.
getLength() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
Returns the length of the valid data currently in the buffer.
getLength() - Method in class org.apache.hadoop.hive.ql.io.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
 
getLength() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
 
getLength(int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
Returns the length of the ith Path.
getLengths() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns an array containing the lengths of the files in the split.
getLengths() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
Returns an array containing the lengths of the files in the split.
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.  
getLineageCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcCtx
Gets the lineage context.
getLineageInfo() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Gets the lineage information.
getLineageInfo() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
Gets the associated lineage information.
getLineageInfo() - Method in class org.apache.hadoop.hive.ql.QueryPlan
Gets the lineage information.
getLineageInfo() - Method in class org.apache.hadoop.hive.ql.session.LineageState
Gets the lineage information.
getLineageInfo(String) - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
parses given query and gets the lineage info.
getLineageState() - Method in class org.apache.hadoop.hive.ql.session.SessionState
Get the lineage state stored in this session.
getLineDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getLineDelim() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getLinfo() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getLint(int) - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintCount() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintList() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintString(int) - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintStringCount() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintStringIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLintStringList() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLintStringSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getList() - Static method in class org.apache.hadoop.hive.ql.exec.MapJoinMetaData
 
getList() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
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
 
getLoadMultiFilesWork() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getLoadTableDesc() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getLoadTableWork() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getLoadTableWork() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getLocalScratchDir(boolean) - Method in class org.apache.hadoop.hive.ql.Context
Create a local scratch directory on demand and return it.
getLocalTmpFileURI() - Method in class org.apache.hadoop.hive.ql.Context
Get a tmp path on local host to store intermediate data.
getLocalWork() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
getLocalWork() - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
getLocation() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getLocation() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getLocation() - Method in class org.apache.hadoop.hive.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.metadata.Partition
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getLocation() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getLocations() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getLocations() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns all the Paths where this input-split resides.
getLocations() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getLocations() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
Returns all the Paths where this input-split resides.
getLocationUri() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getLocationUri() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getLocationUri() - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
getLocationUri() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getLockMode() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getLocks(boolean, boolean) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
getLocks(HiveLockObject, boolean, boolean) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
getLocks(boolean, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
getLocks(HiveLockObject, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
getLockTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getLockTime() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
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
 
getLogRegexes() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getLogWriter() - Method in class org.apache.hadoop.hive.jdbc.HiveDataSource
 
getLong(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getLong(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getLong(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getLong(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
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(int) - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLStringCount() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLStringIterator() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLStringList() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
getLStringSize() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
getLVFProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getMajorVersion() - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
Returns the major version of this driver.
getMajorVersion() - Static method in class org.apache.hadoop.hive.shims.ShimLoader
Return the major version of Hadoop currently on the classpath.
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
 
getMapJoinBigTableAlias() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
getMapJoinContext() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getMapJoinCtx(AbstractMapJoinOperator<? extends MapJoinDesc>) - 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.
getMapJoinQuery() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getMapJoinSubq(int) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getMapJoinUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
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.CreateIndexDesc
 
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
 
getMapOnlySubq(int) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
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(HiveConf) - 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
 
getMatchingSchemaAsRegex() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
Returns the list of filesystem schemas as regex which are permissible for download as a resource.
getMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
getMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_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
Returns the value of maxColumnNameLength.
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
 
getMaxMemory() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getMaxPartitionsPerNode() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
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
 
getMBeanInfo() - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
getMemoryMXBean() - Static method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getMemoryThreshold() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
getMessage() - Method in exception org.apache.hadoop.hive.metastore.api.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.HiveBaseResultSet
 
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.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.persistence.MapJoinObjectValue
 
getMetaHook() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getMetaHook() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getMethodInternal(Class<? extends T>, String, boolean, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
This method is shared between UDFRegistry and UDAFRegistry.
getMethodInternal(Class<?>, List<Method>, boolean, List<TypeInfo>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Gets the closest matching method corresponding to the argument list from a list of methods.
getMethods() - Method in exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
getMHash() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
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.
getMinSplitSize() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getMode() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
getMode() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getMode() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getMode() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getMode() - Method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
 
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
 
getMRScratchDir() - Method in class org.apache.hadoop.hive.ql.Context
Create a map-reduce scratch directory on demand and return it.
getMRTasks(List<Task<? extends Serializable>>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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(Tree) - Method in enum org.apache.hadoop.hive.ql.parse.ErrorMsg
 
getMsg(ASTNode, String) - Method in enum org.apache.hadoop.hive.ql.parse.ErrorMsg
 
getMsg(Tree, String) - 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.proto.test.Complexpb.IntString
 
getMyint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getMyString() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
getMyString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getMyType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldType
 
getMyType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypedef
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
getName() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
getName() - Method in class org.apache.hadoop.hive.metastore.model.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.ConditionalTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.CopyTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
Implements the getName function for the Node Interface.
getName() - Method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
Implements the getName function for the Node Interface.
getName() - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
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.SMBMapJoinOperator
Implements the getName function for the Node Interface.
getName() - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
The operator name for this operator type.
getName() - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
getName() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
getName() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
getName() - Method in class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeTask
 
getName() - Method in enum org.apache.hadoop.hive.ql.index.HiveIndex.IndexType
 
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.lockmgr.HiveLockObj
 
getName() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
getName() - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
getName() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getName() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
getName() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
getName() - Method in class org.apache.hadoop.hive.ql.parse.InputSignature
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
getName() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getNameMessage(Exception) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getNCharacterStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getNCharacterStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getNCharacterStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNCharacterStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNClob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getNClob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getNClob(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNClob(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
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
 
getNew_idx() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
getNew_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
getNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
getNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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.GenericUDAFCollectSet.GenericUDAFMkSetEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Get a new aggregation object.
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
getNewAggregationBuffer() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
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
 
getNewColComment() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewColName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewCols() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewColsString() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewColType() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewDependencyType(LineageInfo.DependencyType, LineageInfo.DependencyType) - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx
Gets the new dependency type by comparing the old dependency type and the current dependency type.
getNewLocation() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNewName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getNext() - Method in class org.apache.hadoop.hive.ql.exec.persistence.DCLLItem
Get the next item.
getNextBlockStart() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
getNextRow() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
Get the next row.
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.
getNGrams() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Returns the final top-k n-grams in a format suitable for returning to Hive.
getNode() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
getNodeType() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getNoSemiJoin() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getNoUnion() - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
getNString(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getNString(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getNString(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNString(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getNthAncestor(Stack<Node>, int) - Static method in class org.apache.hadoop.hive.ql.lib.Utils
Gets the nth ancestor (the parent being the 1st ancestor) in the traversal path.
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
 
getNullSequence() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getNullString() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getNum() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getNum() - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
getNumberBuckets() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
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
 
getNumBuckets() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getNumDistributionKeys() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getNumDPCols() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getNumerator() - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Gets the numerator.
getNumerator() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc.sampleDesc
 
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.
getNumFiles() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getNumGbys() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumInputs() - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getNumInputs() - Method in class org.apache.hadoop.hive.ql.plan.UnionDesc
 
getNumJoins() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getNumMapTasks() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getNumPaths() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the number of Paths in the split.
getNumPaths() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
Returns the number of Paths in the split.
getNumPrecRadix() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
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.ql.exec.Stat
 
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
 
getNumSPCols() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getNumSplits() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
getO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_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_index_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_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_index_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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_index_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_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_database_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_database_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.persistence.MapJoinObjectKey
 
getObj() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
getObj() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
getObj() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
getObj1() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
getObj2() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
getObject(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getObject(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getObject(int, Map<String, Class<?>>) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getObject(String, Map<String, Class<?>>) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
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
 
getObject() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
getObject() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObject
Get the Object.
getObjectDefinition() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
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.TestSerDe
 
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
 
getObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
getObjectInspectors() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObjectInspector
Returns the array of ObjectInspectors that are for each of the tags.
getObjectInspectorsFromEvaluators(Map<Byte, List<ExprNodeEvaluator>>, ObjectInspector[], int) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getObjectName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getObjectName() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getObjectType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getObjectType() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getObjs() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator.IntermediateObject
 
getOffset(int) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the start offset of the ith Path.
getOffset(int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
Returns the start offset of the ith Path.
getOldColName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
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 enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
 
getOp() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getOp() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getOp() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
getOpcode() - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
getOperation() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getOperationName() - Method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
 
getOperationName() - Method in enum org.apache.hadoop.hive.ql.plan.RoleDDLDesc.RoleOperation
 
getOperator() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx.OpToDeleteInfo
 
getOperatorAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorAttributesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorCountersSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getOperatorId() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getOperatorId() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOperatorList() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getOperatorListIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getOperatorListSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getOperatorType() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
getOpParseCtx() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpParseCtxMap() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getOpTaskMap() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getOpToParseCtxMap() - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcCtx
 
getOpToPartList() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpToPartPruner() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.OpWalkerCtx
 
getOpToPartPruner() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpToRemove() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx
 
getOpToSamplePruner() - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.SamplePrunerCtx
 
getOpToSamplePruner() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getOpTreeSkel(Operator<?>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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.
getOrdinalPos() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
getOrigin() - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
 
getOriginalLocation(Partition) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getOrigTable() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getOrigTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getOuterQueryLimit() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getOutExpr(ExprNodeGenericFuncDesc, Object[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
 
getOutPath(String) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
Update OutPath according to tmpPath.
getOutPath(String, Path) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
Update OutPath according to tmpPath.
getOutputColumnLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getOutputColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
getOutputDBLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getOutputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getOutputFileFormatClass() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getOutputFileFormatClassName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getOutputFileFormatClassName() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getOutputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getOutputFormat() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getOutputFormatClass() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getOutputFormatClass() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getOutputFormatFinalPath(Path, String, JobConf, HiveOutputFormat<?, ?>, boolean, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
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.
getOutputInternalColNames() - Method in class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
getOutputKeyColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getOutputObjectInspector() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getOutputRequiredPrivileges() - Method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
Get the output set.
getOutputs() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
getOutputs() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getOutputTableLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputTableList() - Method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
getOutputUserLevelRequiredPriv() - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
getOutputValueColumnNames() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getOutRecordReaderClass() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getOutStream() - Method in class org.apache.hadoop.hive.ql.session.SessionState.LogHelper
 
getOutWriters() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
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
 
getOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
getOwnerName() - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
getP() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
getP() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
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.Database
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getParameters() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getParameters() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
Get the parameter map of the Entity.
getParameters() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getParameters() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getParameters() - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
getParameters() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFParameterInfo
 
getParameters() - Method in class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getParametersSize() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getParameterTypeInfos(Method, int) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Get the parameter TypeInfo for a method.
getParent(Stack<Node>) - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
Returns the parent operator in the walk path to the current operator.
getParent() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx.OpToDeleteInfo
 
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.optimizer.pcr.PcrOpWalkerCtx
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getParseContext() - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx
Gets the parse context.
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
getParseCtx() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
getParsed() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
 
getParsed() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
getParseInfo() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getParseTree() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
getPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getPart_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_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getPart_valsIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getPart_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
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getPart_valsSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
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
 
getPartColumns() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
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, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getPartition(String, String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getPartition() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getPartition() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getPartition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartition(String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartition() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
 
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
 
getPartition(Table, Map<String, String>, boolean, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns partition metadata
getPartitionCols() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getPartitionCols() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getPartitionDesc(Partition) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getPartitionDescFromPath(Map<String, PartitionDesc>, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getPartitionDescFromPathRecursively(Map<String, PartitionDesc>, Path, Map<Map<String, PartitionDesc>, Map<String, PartitionDesc>>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getPartitionDescFromPathRecursively(Map<String, PartitionDesc>, Path, Map<Map<String, PartitionDesc>, Map<String, PartitionDesc>>, boolean) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getPartitionDescMap() - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
getPartitionInformation(Partition) - Static method in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
getPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getPartitionKeys() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
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
 
getPartitionName() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
getPartitionNames(String, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartitionNames(String, String, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
getPartitionNames(String, String, Map<String, String>, short) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
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
 
getPartitionPrivilegeSet(String, String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionPrivilegeSet(String, String, String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitions(String, String, int) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitions(String, String, int) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitions(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
get all the partitions that the table has
getPartitions(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
get all the partitions of the table that matches the given partial specification.
getPartitionsByFilter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsByFilter(String, String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitionsByNames(Table, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
get all the partitions of the table that matches the given partial specification.
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
 
getPartitionsWithAuth(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionsWithAuth(String, String, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitionWithAuth(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getPartitionWithAuth(String, String, List<String>, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getPartitionWithAuthInfo(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getPartitionWithAuthInfo(String, String, List<String>, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
getPartList() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeWork
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getPartSpec() - Method in class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
getPartSpecForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getPartSpecs() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getPartSpecs() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
getPartValues() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getPartValuesFromPartName(String) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
getPartValuesIterator() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getPartValuesSize() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
getPath() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getPath(int) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the ith Path.
getPath() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
getPath() - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
getPath() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getPath(Sample) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getPath() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getPath(int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
Returns the ith Path.
getPaths() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns all the Paths in the split.
getPaths() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
Returns all the Paths in the split.
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_databases_args
 
getPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getPattern() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getPctx() - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
getpGraphContext() - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
getPlan() - Method in class org.apache.hadoop.hive.ql.Driver
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
getPos() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getPosBigTable() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getPosBigTable() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getPosition() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
getPosition() - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataInputBuffer
Returns the current position in the input.
getPosition() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Return the current byte position in the input file.
getPosition(String) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getPosition() - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
getPositionParent(AbstractMapJoinOperator<? extends MapJoinDesc>, Stack<Node>) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getPositionParent(UnionOperator, Stack<Node>) - Static method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory
 
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
 
getPreserved() - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
getPreserved() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getPrev() - Method in class org.apache.hadoop.hive.ql.exec.persistence.DCLLItem
Get the previous item.
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.
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
getPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
getPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
getPrincipalDesc() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getPrincipalDesc() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getPrincipalName() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getPrincipals() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getPrincipals() - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
getPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getPrincipalType() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getPriv() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getPrivilege() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
getPrivilege(Privilege.PrivilegeType) - Static method in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
getPrivilege(int) - Static method in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
getPrivilege(String) - Static method in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
getPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
getPrivileges() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getPrivileges() - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
getPrivilegesIterator() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
getPrivilegesSize() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
getPrivilegeSubjectDesc() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
getPrivilegeSubjectDesc() - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
getPrivTypeByName(String) - Static method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
getPrivTypeByToken(int) - Static method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
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.BucketizedHiveRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
 
getProgress() - Method in class org.apache.hadoop.hive.ql.io.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.PartitionDesc
 
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
 
getPropertyInfo(String, Properties) - Method in class org.apache.hadoop.hive.jdbc.HiveDriver
 
getProps() - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
getProps() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getProtectMode() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getProtectMode() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getProtectModeFromString(String) - Static method in class org.apache.hadoop.hive.metastore.ProtectMode
 
getProtectModeType() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getProtocol(TTransport) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol.Factory
 
getProtocol(TTransport) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol.Factory
 
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
 
getPrunedPartitions() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
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
 
getQMap() - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
getQueries() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Returns an unmodifiable list of queries.
getQueries() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
getQueriesIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
getQueriesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
getQuery() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
getQueryAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryAttributesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryCountersSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getQueryFile() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getQueryFileRegex() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryId() - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
getQueryMatches() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getQueryPlan() - Method in class org.apache.hadoop.hive.ql.Driver
 
getQueryPlan() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getQueryPlan() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryPlan() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
 
getQueryPlan(AsyncMethodCallback<ThriftHive.AsyncClient.getQueryPlan_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
getQueryPlan(AsyncMethodCallback<ThriftHive.AsyncClient.getQueryPlan_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
getQueryPlan() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getQueryPlan() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
getQueryRegex() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getQueryRet() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
The HWISessionItem stores the result of each query in an array.
getQueryStr() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getQueryString() - 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
 
getQueryType() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getQueued() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
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.serde2.ColumnProjectionUtils
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
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat
Create a generic Hive RecordReader than can iterate over all chunks in a CombinedFileSplit.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.RCFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
 
getRecordReader(JobConf, HadoopShims.InputSplitShim, Reporter, Class<RecordReader<K, V>>) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
getRecordWriter(JobConf, HiveOutputFormat<?, ?>, Class<? extends Writable>, boolean, Properties, Path) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hive.ql.io.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>, int, ArrayList<ExprNodeDesc>, List<List<Integer>>, List<String>, List<String>, boolean, int, ArrayList<ExprNodeDesc>, String, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
getReduceSinkDesc(ArrayList<ExprNodeDesc>, ArrayList<ExprNodeDesc>, List<String>, boolean, int, int, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
getReduceSinkDesc(ArrayList<ExprNodeDesc>, int, ArrayList<ExprNodeDesc>, List<List<Integer>>, List<String>, List<String>, boolean, int, int, int) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Create the reduce sink descriptor.
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.
getReduceSinkProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
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.HiveBaseResultSet
 
getRef(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getRef(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getRef(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getReflectionObjectInspector(Type, ObjectInspectorFactory.ObjectInspectorOptions) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getRegexToLogLines() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
getRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
getRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
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.DescDatabaseDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getResFile() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getResFileString() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
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
 
getResponseCode() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_index_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_database_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_index_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_database_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_type_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_database_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_index_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_type_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_databases_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_tables_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_config_value_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_database_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_databases_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_with_signature_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_names_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_indexes_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_by_name_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_privilege_set_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_names_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_tables_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_all_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_privileges_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_role_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_privileges_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_roles_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.renew_delegation_token_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_privileges_call
 
getResult() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_role_call
 
getResult() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
getResult() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
getResult() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.execute_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchAll_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchN_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchOne_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getClusterStatus_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getQueryPlan_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getSchema_call
 
getResult() - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getThriftSchema_call
 
getResultBucket() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
gets the value for resultBucket.
getResultBucketMaxSize() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
returns the value for resultBucketMaxSize.
getResultFile() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
getResults(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.Driver
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getResultSchema() - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
getResultsDirectory() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getResultSet() - Method in class org.apache.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.HashTableSinkDesc
 
getRetainList() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getRetention() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getRetention() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getRetention() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getReversedExprs() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getReversedExprs() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getRevokeDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getRHSSemijoinColumns(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getRight() - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
getRight() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getRightAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getRole() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
getRole() - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
getRole(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getRole(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
getRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
getRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
getRoleDDLDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getRoleGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
getRoleName() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
getRoleName() - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
getRoleOwnerName() - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
getRolePrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getRolePrivilegesSize() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getRoles() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
getRootMapJoinOp() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
getRootOps() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getRootPath() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getRoots() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getRootsIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getRootsSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
getRootTask(int) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
getRootTasks() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getRow() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getRowContainer(Configuration, List<ObjectInspector>, Byte, int, Map<Byte, TableDesc>, JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getRowId(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getRowId(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getRowId(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getRowId(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getRowIdLifetime() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getRowResolver() - Method in class org.apache.hadoop.hive.ql.parse.OpParseContext
 
getRowResolver(Operator) - Method in class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
Get the row resolver given an operator.
getRowResolver(Node) - Method in class org.apache.hadoop.hive.ql.ppd.OpWalkerInfo
 
getRowSchema() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getRowSeparator() - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
getRowTypeInfo() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getRslvMap() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getRSProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getRunDisabled() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getRunnable() - Method in class org.apache.hadoop.hive.ql.DriverContext
 
getS() - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
getSampleDescr() - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
getSampleDimension() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
getSampleFraction() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
getSampleNum() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
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(Partition, Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getSchema(StorageDescriptor, StorageDescriptor, Map<String, String>, String, String, List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
getSchema() - Method in class org.apache.hadoop.hive.ql.Driver
 
getSchema(BaseSemanticAnalyzer, HiveConf) - Static method in class org.apache.hadoop.hive.ql.Driver
Get a Schema with fields represented with native Hive types
getSchema() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getSchema() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSchema() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getSchema() - Static method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
getSchema() - Static method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.SchemaDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
getSchema() - Static method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getSchema() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getSchema() - Method in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
Return the Hive schema of the query result.
getSchema(AsyncMethodCallback<ThriftHive.AsyncClient.getSchema_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
getSchema(AsyncMethodCallback<ThriftHive.AsyncClient.getSchema_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
getSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getSchema() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
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
 
getSchemaString() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getSchemaTerm() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getScope(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
getScriptCmd() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getScriptErrInfo() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getScriptInputInfo() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getScriptOutputInfo() - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
getSCRProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
getSd() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getSd() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
getSd() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getSd() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
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
 
getSelProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getSemanticAnalyzerHook(HiveConf, String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyListObjectInspector
Returns the separator for delimiting items in this array.
getSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazySimpleStructObjectInspector
 
getSeparator() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getSeparators() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
getSerDe() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator.HashTableSinkObjectCtx
 
getSerde() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getSerDeClass() - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
getSerDeClass() - Method in interface org.apache.hadoop.hive.ql.metadata.HiveStorageHandler
 
getSerdeClassName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getSerdeClassName() - Method in class org.apache.hadoop.hive.ql.plan.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
 
getSerdeProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getSerdeProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
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.TestSerDe
 
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.HiveBaseResultSet
 
getShort(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getShort(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getShort(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getShort(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the short value out of a primitive object.
getShortName() - Method in class org.apache.hadoop.hive.serde2.TestSerDe
 
getShowDatabasesDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowFuncsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowGrantDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowIndexesDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowLocksDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowPartsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowTblsDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getShowTblStatusDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getSignature() - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
getSkewKeyDefinition() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getSkewKeyDefinition() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getSkewKeysValuesTables() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getSkewKeysValuesTables() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getSmallKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getSmallKeysDirMap() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
getSmallTableOnlySet(JoinCondDesc[]) - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
 
getSolution() - Method in class org.apache.hadoop.hive.ql.exec.errors.ErrorAndSolution
 
getSortByForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Get the Sort By AST for the clause.
getSortColNames() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSortCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSortCols() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getSortCols() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getSortColsIterator() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSortColsSize() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
getSortColumns() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getSourceDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadDesc
 
getSourceDirs() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getSPColNames() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getSpec() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getSpillSerDe(byte, Map<Byte, TableDesc>, JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getSpillTableDesc(Byte, Map<Byte, TableDesc>, JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getSpillTableDesc(Map<Byte, TableDesc>, JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getSplit(int) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
getSplitNum() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat
Create Hive splits based on CombineFileSplit.
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
Parses all target paths from job input directory which contains symlink files, and splits the target data using TextInputFormat.
getSplits(JobConf, int) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.CombineFileInputFormatShim
 
getSPPath() - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
getSQLKeywords() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSQLState() - Method in enum org.apache.hadoop.hive.ql.parse.ErrorMsg
 
getSQLState() - Method in class org.apache.hadoop.hive.ql.processors.CommandProcessorResponse
 
getSQLState() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
getSQLStateType() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getSqlTableType() - Method in class org.apache.hadoop.hive.jdbc.JdbcTable
 
getSqlType() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
getSQLXML(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getSQLXML(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getSQLXML(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getSQLXML(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getSrcForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getSrcForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getSSIsSilent() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is a chained call to SessionState.getIsSilent().
getStageAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageAttributesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageCountersSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getStageId() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getStageID() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getStageList() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getStageListIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getStageListSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
getStageType() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
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.HashTableSinkOperator
 
getStandardObjectInspectors(Map<Byte, List<ObjectInspector>>, int) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
getStandardOI() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator.HashTableSinkObjectCtx
 
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
 
getStandardUnionObjectInspector(List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getStandardUnionTypeName(UnionObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
getStandardWritableObjectInspectorFromTypeInfo(TypeInfo) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoUtils
Returns the standard object inspector that can be used to translate an object of that typeInfo to a standard object type.
getStart() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
The position of the first byte in the file to process.
getStart() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
The position of the first byte in the file to process.
getStart() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getStart() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
 
getStarted() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
getStartOffsets() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns an array containing the startoffsets of the files in the split.
getStartOffsets() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
Returns an array containing the startoffsets of the files in the split.
getState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getStatement() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getStaticSpec() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
getStatsAggPrefix() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
Construct the key prefix used as (intermediate) statistics publishing and aggregation.
getStatsAggPrefix() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getStatsAggregator() - Static method in class org.apache.hadoop.hive.ql.stats.StatsFactory
Returns a Stats Aggregator implementation class for the IStatsAggregator interface For example HBaseStatsAggregator for the HBase implementation
getStatsPublisher(JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getStatsPublisher() - Static method in class org.apache.hadoop.hive.ql.stats.StatsFactory
Returns a Stats publisher implementation class for the IStatsPublisher interface For example HBaseStatsPublisher for the HBase implementation
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.
getStorageHandler(Configuration, String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
getStorageHandler() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getStorageHandler() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
getStorageHandler() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getStorageHandler() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getStream() - Method in class org.apache.hadoop.hive.ql.Context
 
getStreamAliases() - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
getStrExprProcessor() - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory
Factory method to get StrExprProcessor.
getString(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getString(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getString(int) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getString(String) - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
getString(Object, PrimitiveObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the String value out of a primitive object.
getStringColumn(String) - Static method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
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.SubStructObjectInspector
 
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.SubStructObjectInspector
 
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.SubStructObjectInspector
 
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_index_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_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_all_databases_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
getSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
getSuccessIterator() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
getSuccessSize() - Method in class org.apache.hadoop.hive.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
 
getSwitchDatabaseDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getSystemFunctions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getT() - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
getT() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcCtx
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprPrunerInfo
 
getTabAlias() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
getTabAliases() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getTable(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTable(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Deprecated. 
getTable(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Deprecated. As of release 0.6.0 replaced by IMetaStoreClient.getTable(String, String). This method will be removed in release 0.7.0.
getTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get a table object.
getTable() - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
getTable() - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
getTable() - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
getTable(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTable(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getTable() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
 
getTable() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
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) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns metadata for the table named tableName
getTable(String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns metadata for the table named tableName
getTable(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns metadata of the table
getTable(String, String, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns metadata of the table
getTable() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
getTable() - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
getTable_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
 
getTableCatalog() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
getTableCatalog() - Method in class org.apache.hadoop.hive.jdbc.JdbcTable
 
getTableDesc() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getTableDesc(Table) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getTableDesc(String, String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
getTableDesc() - Method in class org.apache.hadoop.hive.ql.parse.QB
 
getTableDesc() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getTableDesc(Class<? extends Deserializer>, String, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor of given serde with the separatorCode and column names (comma separated string).
getTableDesc(Class<? extends Deserializer>, String, String, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate the table descriptor of the serde specified with the separatorCode and column names (comma separated string), and whether the last column should take the rest of the line.
getTableDesc(Class<? extends Deserializer>, String, String, String, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getTableDesc(Class<? extends Deserializer>, String, String, String, boolean, boolean) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getTableDesc(Class<? extends Deserializer>, String, String, String, boolean, boolean, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
 
getTableDesc(CreateTableDesc, String, String) - Static method in class org.apache.hadoop.hive.ql.plan.PlanUtils
Generate a table descriptor from a createTableDesc.
getTableForAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
getTableInfo() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getTableInformation(Table) - Static method in class org.apache.hadoop.hive.ql.metadata.MetaDataFormatUtils
 
getTableName(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
getTableName() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
getTableName() - Method in class org.apache.hadoop.hive.jdbc.JdbcTable
 
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 class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
getTableName() - Method in exception org.apache.hadoop.hive.ql.metadata.InvalidTableException
 
getTableName() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
getTableName() - Method in class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
getTableNames() - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
getTablePrivileges(String, String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getTablePrivilegeSet(String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTablePrivilegeSet(String, String, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
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
Get the names of all tables in the specified database that satisfy the supplied table name pattern.
getTables(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Get the names of all tables in the specified database that satisfy the supplied table name pattern.
getTables(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getTables(String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getTablesByPattern(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns all existing tables from default database which match the given pattern.
getTablesByPattern(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns all existing tables from the specified database which match the given pattern.
getTableScanMapJoin() - Static method in class org.apache.hadoop.hive.ql.optimizer.MapJoinFactory
 
getTableScanProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
Factory method to get the ColumnPrunerDefaultProc class.
getTablesForDb(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Returns all existing tables from the given database which match the given pattern.
getTablesNotInMs() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
getTablesNotOnFs() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
getTableSpec(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getTableSpec() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
This method is used only for the anlayze command to get the partition specs
getTableSpecs() - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
getTableType() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getTableType() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getTableType() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
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
 
getTag() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyUnion
Get the tag of the union
getTag(Object) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getTag(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
Return the tag of the object.
getTag() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
getTag() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObject
Get the tag of the union.
getTag(Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.UnionObjectInspector
Return the tag of the object.
getTagOrder() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getTagOrder() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
The order in which tables should be processed when joining.
getTagToAlias() - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
getTagToValueDesc() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getTargetDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
getTargetDirs() - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
getTargetSplit() - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
Gets the target split, i.e.
getTask() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
getTaskAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskAttributesSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskCountersSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskId(Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Gets the task id if we are running as a Hadoop job.
getTaskId() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTaskIdFromFilename(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Get the task id from the filename.
getTaskInfoMap() - Method in class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
getTaskJobIDs(TaskCompletionEvent) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
getTaskJobIDs returns an array of String with two elements.
getTaskList() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getTaskListIterator() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getTaskListSize() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
getTasks(HiveConf, Object) - Method in interface org.apache.hadoop.hive.ql.plan.ConditionalResolver
All conditional resolvers implement this interface.
getTasks(HiveConf, Object) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin
 
getTasks(HiveConf, Object) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles
 
getTasks(HiveConf, Object) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin
 
getTaskTag() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
getTaskTmpDir() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
getTaskTmpDir() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
getTaskType() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
getTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
getTbl() - Method in class org.apache.hadoop.hive.ql.plan.HashTableDummyDesc
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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.append_partition_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_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.exec.HashTableSinkOperator.HashTableSinkObjectCtx
 
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
 
getTblProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
getTblProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
getTblProps() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getTemplate() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getTemplatePath() - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
getTHRESHOLD() - Static method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
 
getThriftFieldId() - Method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
 
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(AsyncMethodCallback<ThriftHive.AsyncClient.getThriftSchema_call>) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
getThriftSchema(AsyncMethodCallback<ThriftHive.AsyncClient.getThriftSchema_call>) - Method in interface org.apache.hadoop.hive.service.ThriftHive.AsyncIface
 
getThriftSchema() - Method in class org.apache.hadoop.hive.service.ThriftHive.Client
 
getThriftSchema() - Method in interface org.apache.hadoop.hive.service.ThriftHive.Iface
 
getTime(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getTime(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getTime(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getTime(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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
 
getTimeDateFunctions() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getTimestamp(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getTimestamp(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getTimestamp(int, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getTimestamp(String, Calendar) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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
 
getTmpDir() - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
getTmpFileURI() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
getTmpHDFSFileURI() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
getToken(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Get the specific Token.
getToken_signature() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
getToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
getToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
getTokenNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getTokenRewriteStream() - Method in class org.apache.hadoop.hive.ql.Context
 
getTokenStrForm() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
getTokenStrForm(String) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Get the string form of the token given a token signature.
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
 
getTotalFiles() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
getToWalk() - Method in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
getToWalk() - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
 
getTPartition() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Should be only used by serialization.
getTransactionIsolation() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
getTransformProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.aliasList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseSuffixProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterIndexStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterProtectMode_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterProtectModeMode_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementChangeColPosition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.alterStatementSuffixArchive_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixClusterbySortby_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixDropPartitions_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixFileFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixLocation_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixProtectMode_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRename_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRenameCol_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixSerdeProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixTouch_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixUnArchive_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterTableStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterTblPartitionStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterTblPartitionStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterViewStatementSuffix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.alterViewSuffixProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.analyzeStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.atomExpression_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.autoRebuild_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.body_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.colTypeList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameColonType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameColonTypeList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameComment_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameCommentList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameOrder_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameOrderList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameTypeList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.columnRefOrder_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.constant_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createDatabaseStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createFunctionStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createIndexStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createRoleStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createTableStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.createViewStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.databaseComment_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dbProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dbPropertiesList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.ddlStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.descFuncNames_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.dropDatabaseStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropFunctionStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropIndexStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropRoleStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropTableStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.dropViewStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.execStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.expressions_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.fileFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.grantPrivileges_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.grantRole_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.havingClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.havingCondition_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.ifExists_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.ifNotExists_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexComment_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexPropertiesList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexPropertiesPrefixed_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.indexTblName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.inOperator_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.kwRole_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.kwUser_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.lateralView_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.lockMode_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.lockStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.mapType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.metastoreCheck_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.principalName_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.principalSpecification_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeIncludeColObject_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeObject_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.privlegeDef_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.recordReader_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.recordWriter_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.regular_body_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.revokePrivileges_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.revokeRole_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormatDelimited_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormatSerde_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.selectStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.selectTrfmClause_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showGrants_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.showRoleGrants_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.structType_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.switchDatabaseStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.sysFuncNames_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableAlias_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.tableName_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.tableOrPartition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tablePartition_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tablePartitionPrefix_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableProperties_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tablePropertiesList_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tablePropertiesPrefixed_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormat_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatCollItemsIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatFieldIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatLinesIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatMapKeysIdentifier_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.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.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.unionType_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.uniqueJoinExpr_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.uniqueJoinSource_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.uniqueJoinToken_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.unlockStatement_return
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.viewName_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
 
getTree() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser.withOption_return
 
getTreeAdaptor() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
getTSProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getTSProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getTTable() - Method in class org.apache.hadoop.hive.ql.metadata.Table
This function should only be used in serialization.
getTTDesc() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.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
 
getTyp() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
getType() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getType() - Method in class org.apache.hadoop.hive.jdbc.JdbcColumn
 
getType() - Method in class org.apache.hadoop.hive.jdbc.JdbcTable
 
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.AbstractMapJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.CopyTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.Operator
Return the type of the specific operator among the types in OperatorType.
getType() - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.Task
Should be overridden to return the type of the specific task among the types in StageType.
getType() - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
getType() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
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.index.compact.IndexMetadataChangeTask
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.ArchiveWork
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
getType() - Method in class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
getType() - Method in class org.apache.hadoop.hive.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() - Static method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
getTypeInfo() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
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 class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
getTypeName() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector
Returns the name of the data type that is inspected by this ObjectInspector.
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveObjectInspector
Return the type name for this primitive ObjectInspector.
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
getTypeName() - Method in class org.apache.hadoop.hive.serde2.objectinspector.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.
getTypeName() - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
getTypeNameFromJavaClass(Type) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Get the type name of the Java class.
getTypeNameFromPrimitiveJava(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the typeName from a Java Primitive Type or Java PrimitiveClass.
getTypeNameFromPrimitiveWritable(Class<?>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
Get the typeName from a Primitive Writable Class.
getTypeString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
getTypeStringFromAST(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getUCtx() - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
getUDAFClass() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge
 
getUdafEvaluator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFBridge.GenericUDAFBridgeEvaluator
 
getUdfClass() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getUdfName() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
getUDTFName() - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
getUDTFProc() - Static method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
getUDTs(String, String, String, int[]) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getUgi() - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
getUGIForConf(Configuration) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Get the UGI that the given job configuration will run as.
getUnderscore_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
getUnderscoreInt() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
getUnescapedName(ASTNode) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
getUnicodeStream(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
getUnicodeStream(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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
 
getUnionProc() - Static method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
getUnionStructObjectInspector(List<StructObjectInspector>) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory
 
getUnionTask(UnionOperator) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
getUnionTypeInfo(List<TypeInfo>) - Static method in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
getUnixScriptNameFor(String) - Static method in class org.apache.hadoop.hive.ql.util.DosToUnix
 
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
 
getUnlockTblDesc() - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
getUnparsedColumnNamesFromFieldSchema(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
Convert FieldSchemas to columnNames with backticks around them.
getUnparseTranslator() - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
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.HiveBaseResultSet
 
getURL(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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(JobConf) - Static method in class org.apache.hadoop.hive.ql.exec.JobTrackerURLResolver
 
getUsageAlias() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getUsageNode() - Method in class org.apache.hadoop.hive.ql.parse.ASTNodeOrigin
 
getUsedBins() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Returns the number of bins currently being used by the histogram.
getUser() - Method in class org.apache.hadoop.hive.conf.HiveConf
 
getUser() - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
getUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
getUserGrants() - Method in class org.apache.hadoop.hive.ql.session.CreateTableAutomaticGrant
 
getUserName() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
getUserName() - Method in class org.apache.hadoop.hive.ql.security.DummyAuthenticator
 
getUserName() - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
getUserName() - Method in interface org.apache.hadoop.hive.ql.security.HiveAuthenticationProvider
 
getUserPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getUserPrivilegeSet(String, List<String>) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
getUserPrivilegeSet(String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
getUserPrivilegesSize() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
getUTask() - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRUnionCtx
 
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.HiveObjectType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.metastore.api.PrincipalType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.AdjacencyType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.NodeType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.OperatorType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.StageType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.hadoop.hive.ql.plan.api.TaskType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
getValue() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
getValue() - Method in enum org.apache.hadoop.hive.service.JobTrackerState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValueClass() - Method in class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
getValueCols() - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
getValueFilteredTblDescs() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
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.HashTableSinkDesc
 
getValueTblDescs() - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
getValueTblFilteredDescs() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
getValueType() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeTypeMap
 
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
 
getViewExpandedText() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getViewExpandedText() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getViewExpandedText() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getViewExpandedText() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getViewName() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
getViewOriginalText() - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
getVirtualCols() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
getWarnings() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.HiveStatement
 
getWhrForClause(String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
getWork() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
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
 
go() - Method in class org.apache.hadoop.hive.ql.exec.AutoProgressor
 
grant_privileges(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_privileges_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
grant_privileges(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_privileges_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
grant_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
grant_privileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
grant_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
grant_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
grant_privileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
GrantDesc - Class in org.apache.hadoop.hive.ql.plan
 
GrantDesc(PrivilegeObjectDesc, List<PrivilegeDesc>, List<PrincipalDesc>, String, PrincipalType, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.GrantDesc
 
grantPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
grantPrivileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
grantPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
grantPrivileges() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
GrantRevokeRoleDDL - Class in org.apache.hadoop.hive.ql.plan
 
GrantRevokeRoleDDL() - Constructor for class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
GrantRevokeRoleDDL(boolean, List<String>, List<PrincipalDesc>, String, PrincipalType, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
grantRole(Role, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
grantRole(Role, String, PrincipalType, String, PrincipalType, boolean) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
grantRole(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
grantRole() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Graph - Class in org.apache.hadoop.hive.ql.plan.api
 
Graph() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Graph
 
Graph(NodeType, List<String>, List<Adjacency>) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Graph
 
Graph(Graph) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Graph
Performs a deep copy on other.
Graph._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GraphWalker - Interface in org.apache.hadoop.hive.ql.lib
Interface for operator graph walker.
GREATERTHAN - 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.
GroupByDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
GroupByDesc(GroupByDesc.Mode, ArrayList<String>, ArrayList<ExprNodeDesc>, ArrayList<AggregationDesc>, boolean, float, float) - Constructor for class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
GroupByDesc(GroupByDesc.Mode, ArrayList<String>, ArrayList<ExprNodeDesc>, ArrayList<AggregationDesc>, boolean, boolean, float, float) - Constructor for class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
GroupByDesc.Mode - Enum in org.apache.hadoop.hive.ql.plan
Mode.
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
 
GroupByOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
this transformation does bucket group by optimization.
GroupByOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer
 
GroupByOptimizer.BucketGroupByProcessor - Class in org.apache.hadoop.hive.ql.optimizer
BucketGroupByProcessor.
GroupByOptimizer.BucketGroupByProcessor(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.BucketGroupByProcessor
 
GroupByOptimizer.GroupByOptProcCtx - Class in org.apache.hadoop.hive.ql.optimizer
GroupByOptProcCtx.
GroupByOptimizer.GroupByOptProcCtx() - Constructor for class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.GroupByOptProcCtx
 
groupKeyObject - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 

H

HADOOP_LOCAL_FS - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
The object in the reducer are composed of these top level fields.
HadoopDefaultAuthenticator - Class in org.apache.hadoop.hive.ql.security
 
HadoopDefaultAuthenticator() - Constructor for class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
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.CombineFileInputFormatShim<K,V> - Interface in org.apache.hadoop.hive.shims
CombineFileInputFormatShim.
HadoopShims.InputSplitShim - Interface in org.apache.hadoop.hive.shims
InputSplitShim.
HadoopShims.MiniDFSShim - Interface in org.apache.hadoop.hive.shims
Shim around the functions in MiniDFSCluster that Hive uses.
HadoopThriftAuthBridge - Class in org.apache.hadoop.hive.thrift
This class is only overridden by the secure hadoop shim.
HadoopThriftAuthBridge() - Constructor for class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge
 
HadoopThriftAuthBridge.Client - Class in org.apache.hadoop.hive.thrift
 
HadoopThriftAuthBridge.Client() - Constructor for class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Client
 
HadoopThriftAuthBridge.Server - Class in org.apache.hadoop.hive.thrift
 
HadoopThriftAuthBridge.Server() - Constructor for class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
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.
handleGenericFileFormat(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
handleSkew(int) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
hasAint() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
hasAnyNullObject(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
True if Object passed is representing null object.
hasAnyNulls(ArrayList<Object>) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
hasAnyNulls(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
hasAnyNulls(AbstractMapJoinKey) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
hasAnyNulls() - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinKey
 
hasAnyNulls() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
hasAnyNulls() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
hasAnyNulls() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
hasAString() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
hasColumnExpr(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Whether the expression contains a column node or not.
hasExprToColumnAlias(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
hasGroupBy(Operator<? extends Serializable>, MapJoinResolver.LocalMapJoinProcCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.LocalMapJoinProcessor
 
hashAggregations - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
hashBytes(byte[], int, int) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazyUtils
 
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 exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
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.HiveObjectPrivilege
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
hashCode() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
hashCode() - Method in 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.PrincipalPrivilegeSet
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
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_index_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_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_index_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_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_all_databases_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.ThriftHiveMetastore.grant_privileges_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
hashCode() - Method in class org.apache.hadoop.hive.metastore.api.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.errors.ErrorAndSolution
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinKey
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
hashCode() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
hashCode() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
 
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.io.RecordTestObj
 
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.ql.plan.api.Adjacency
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
hashCode() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
hashCode() - Method in class org.apache.hadoop.hive.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() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyNonPrimitive
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazy.LazyPrimitive
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryNonPrimitive
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryObject
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryPrimitive
 
hashCode(Object, ObjectInspector) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.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.serde2.typeinfo.TypeInfo
 
hashCode() - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
 
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.getQueryPlan_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
hashCode() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
HashMapWrapper<K,V> - Class in org.apache.hadoop.hive.ql.exec.persistence
Simple wrapper for persistent Hashmap implementing only the put/get/remove/clear interface.
HashMapWrapper(int, float, float) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
Constructor.
HashMapWrapper(int) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
HashMapWrapper() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
HashTableDummyDesc - Class in org.apache.hadoop.hive.ql.plan
HashTable Dummy Descriptor implementation.
HashTableDummyDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.HashTableDummyDesc
 
HashTableDummyOperator - Class in org.apache.hadoop.hive.ql.exec
 
HashTableDummyOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
HashTableSinkDesc - Class in org.apache.hadoop.hive.ql.plan
Map Join operator Descriptor implementation.
HashTableSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
HashTableSinkDesc(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
HashTableSinkOperator - Class in org.apache.hadoop.hive.ql.exec
 
HashTableSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
HashTableSinkOperator(MapJoinOperator) - Constructor for class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
HashTableSinkOperator.HashTableSinkObjectCtx - Class in org.apache.hadoop.hive.ql.exec
 
HashTableSinkOperator.HashTableSinkObjectCtx(ObjectInspector, SerDe, TableDesc, Configuration) - Constructor for class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator.HashTableSinkObjectCtx
 
hasKey(String) - Method in interface org.apache.hadoop.hive.common.metrics.MetricsMBean
Check if we're tracking a certain named key/metric
hasKey(String) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
hasMyint() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
hasMyString() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
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.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
 
hasUnderscoreInt() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
havingClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
havingCondition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
HBASE_IMPL_CLASS_VAL - Static variable in class org.apache.hadoop.hive.ql.stats.StatsSetupConst
The value of the user variable "hive.stats.dbclass" to use HBase implementation.
head() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MRU
Get the most recently used.
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
 
heartbeatInterval - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
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_COLUMN_ORDER_ASC - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
HIVE_COLUMN_ORDER_DESC - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
hive_db - Variable in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
HIVE_EXEC_L4J - Static variable in class org.apache.hadoop.hive.ql.session.SessionState
 
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
 
HiveAuthenticationProvider - Interface in org.apache.hadoop.hive.ql.security
HiveAuthenticationProvider is an interface for authentication.
HiveAuthorizationProvider - Interface in org.apache.hadoop.hive.ql.security.authorization
Hive's pluggable authorization provider interface
HiveAuthorizationProviderBase - Class in org.apache.hadoop.hive.ql.security.authorization
 
HiveAuthorizationProviderBase() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
HiveBaseResultSet - Class in org.apache.hadoop.hive.jdbc
Data independed base class which implements the common part of all hive resultsets.
HiveBaseResultSet() - Constructor for class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
HiveBinaryOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
HiveBinaryOutputFormat writes out the values consecutively without any separators.
HiveBinaryOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveBinaryOutputFormat
 
HiveCallableStatement - Class in org.apache.hadoop.hive.jdbc
HiveCallableStatement.
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, JobTrackerState) - Constructor for class org.apache.hadoop.hive.service.HiveClusterStatus
 
HiveClusterStatus(HiveClusterStatus) - Constructor for class org.apache.hadoop.hive.service.HiveClusterStatus
Performs a deep copy on other.
HiveClusterStatus._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HiveCompactIndexInputFormat - Class in org.apache.hadoop.hive.ql.index.compact
 
HiveCompactIndexInputFormat() - Constructor for class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexInputFormat
 
HiveCompactIndexResult - Class in org.apache.hadoop.hive.ql.index.compact
 
HiveCompactIndexResult(String, JobConf) - Constructor for class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexResult
 
HiveConf - Class in org.apache.hadoop.hive.conf
Hive Configuration.
HiveConf() - Constructor for class org.apache.hadoop.hive.conf.HiveConf
 
HiveConf(Class<?>) - Constructor for class org.apache.hadoop.hive.conf.HiveConf
 
HiveConf(Configuration, Class<?>) - Constructor for class org.apache.hadoop.hive.conf.HiveConf
 
HiveConf(HiveConf) - Constructor for class org.apache.hadoop.hive.conf.HiveConf
Copy constructor
hiveConf - Static variable in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
HiveConf.ConfVars - Enum in org.apache.hadoop.hive.conf
ConfVars.
HIVECONF_PREFIX - Static variable in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
HiveConnection - Class in org.apache.hadoop.hive.jdbc
HiveConnection.
HiveConnection(String, Properties) - Constructor for class org.apache.hadoop.hive.jdbc.HiveConnection
TODO: - parse uri (use java.net.URI?).
HiveContextAwareRecordReader<K,V> - Class in org.apache.hadoop.hive.ql.io
 
HiveContextAwareRecordReader() - Constructor for class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
HiveDatabaseMetaData - Class in org.apache.hadoop.hive.jdbc
HiveDatabaseMetaData.
HiveDatabaseMetaData(HiveInterface) - Constructor for class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
HiveDataSource - Class in org.apache.hadoop.hive.jdbc
HiveDataSource.
HiveDataSource() - Constructor for class org.apache.hadoop.hive.jdbc.HiveDataSource
 
HiveDriver - Class in org.apache.hadoop.hive.jdbc
HiveDriver.
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.
hiveHist - Variable in class org.apache.hadoop.hive.ql.session.SessionState
 
HiveHistory - Class in org.apache.hadoop.hive.ql.history
HiveHistory.
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
Info.
HiveHistory.Info() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.Info
 
HiveHistory.Keys - Enum in org.apache.hadoop.hive.ql.history
Keys.
HiveHistory.Listener - Interface in org.apache.hadoop.hive.ql.history
Listner interface Parser will call handle function for each record type.
HiveHistory.QueryInfo - Class in org.apache.hadoop.hive.ql.history
QueryInfo.
HiveHistory.QueryInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
HiveHistory.RecordTypes - Enum in org.apache.hadoop.hive.ql.history
RecordTypes.
HiveHistory.SessionInfo - Class in org.apache.hadoop.hive.ql.history
SessionInfo.
HiveHistory.SessionInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.SessionInfo
 
HiveHistory.TaskInfo - Class in org.apache.hadoop.hive.ql.history
TaskInfo.
HiveHistory.TaskInfo() - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistory.TaskInfo
 
HiveHistoryViewer - Class in org.apache.hadoop.hive.ql.history
HiveHistoryViewer.
HiveHistoryViewer(String) - Constructor for class org.apache.hadoop.hive.ql.history.HiveHistoryViewer
 
HiveIgnoreKeyTextOutputFormat<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
HiveIgnoreKeyTextOutputFormat replaces key with null before feeding the to TextOutputFormat.RecordWriter.
HiveIgnoreKeyTextOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
 
HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
 
HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter(RecordWriter<K, V>) - Constructor for class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter
 
HiveIndex - Class in org.apache.hadoop.hive.ql.index
Holds index related constants
HiveIndex() - Constructor for class org.apache.hadoop.hive.ql.index.HiveIndex
 
HiveIndex.IndexType - Enum in org.apache.hadoop.hive.ql.index
 
HiveIndexHandler - Interface in org.apache.hadoop.hive.ql.index
HiveIndexHandler defines a pluggable interface for adding new index handlers to Hive.
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
 
HiveLock - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLock() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLock
 
HiveLockManager - Interface in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockManagerCtx - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockManagerCtx() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockManagerCtx
 
HiveLockManagerCtx(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockManagerCtx
 
hiveLockMgr - Variable in class org.apache.hadoop.hive.ql.Context
 
HiveLockMode - Enum in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockObj - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockObj(HiveLockObject, HiveLockMode) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
HiveLockObject - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockObject() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(String, HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(String[], HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(Table, HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(Partition, HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject(DummyPartition, HiveLockObject.HiveLockObjectData) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
HiveLockObject.HiveLockObjectData - Class in org.apache.hadoop.hive.ql.lockmgr
 
HiveLockObject.HiveLockObjectData(String, String, String) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
HiveLockObject.HiveLockObjectData(String) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
hiveLocks - Variable in class org.apache.hadoop.hive.ql.Context
 
HiveMetaDataResultSet<M> - Class in org.apache.hadoop.hive.jdbc
 
HiveMetaDataResultSet(List<String>, List<String>, List<M>) - Constructor for class org.apache.hadoop.hive.jdbc.HiveMetaDataResultSet
 
HiveMetaException - Exception in org.apache.hadoop.hive.metastore
 
HiveMetaException() - Constructor for exception org.apache.hadoop.hive.metastore.HiveMetaException
 
HiveMetaException(String) - Constructor for exception org.apache.hadoop.hive.metastore.HiveMetaException
 
HiveMetaException(Throwable) - Constructor for exception org.apache.hadoop.hive.metastore.HiveMetaException
 
HiveMetaException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.metastore.HiveMetaException
 
HiveMetaHook - Interface in org.apache.hadoop.hive.metastore
HiveMetaHook defines notification methods which are invoked as part of transactions against the metastore, allowing external catalogs such as HBase to be kept in sync with Hive's metastore.
HiveMetaHookLoader - Interface in org.apache.hadoop.hive.metastore
HiveMetaHookLoader is responsible for loading a HiveMetaHook for a given table.
HiveMetaStore - Class in org.apache.hadoop.hive.metastore
TODO:pc remove application logic to a separate interface.
HiveMetaStore() - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStore
 
HiveMetaStore.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
 
HiveMetaStoreClient(HiveConf, HiveMetaHookLoader) - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
HiveMetaStoreFsImpl - Class in org.apache.hadoop.hive.metastore
 
HiveMetaStoreFsImpl() - Constructor for class org.apache.hadoop.hive.metastore.HiveMetaStoreFsImpl
 
HiveNullValueSequenceFileOutputFormat - Class in org.apache.hadoop.hive.ql.io
A HiveOutputFormat that writes SequenceFiles with the content saved in the keys, and null in the values.
HiveNullValueSequenceFileOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.HiveNullValueSequenceFileOutputFormat
 
HiveObjectPrivilege - Class in org.apache.hadoop.hive.metastore.api
 
HiveObjectPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
HiveObjectPrivilege(HiveObjectRef, String, PrincipalType, PrivilegeGrantInfo) - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
HiveObjectPrivilege(HiveObjectPrivilege) - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Performs a deep copy on other.
HiveObjectPrivilege._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HiveObjectRef - Class in org.apache.hadoop.hive.metastore.api
 
HiveObjectRef() - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
HiveObjectRef(HiveObjectType, String, String, List<String>, String) - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
HiveObjectRef(HiveObjectRef) - Constructor for class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Performs a deep copy on other.
HiveObjectRef._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HiveObjectType - Enum in org.apache.hadoop.hive.metastore.api
 
HiveOperation - Enum in org.apache.hadoop.hive.ql.plan
 
HiveOperation.PrivilegeAgreement - Class in org.apache.hadoop.hive.ql.plan
 
HiveOperation.PrivilegeAgreement() - Constructor for class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
hiveOutputFormat - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
HiveParser(TokenStream) - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser
 
HiveParser.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.alterDatabaseStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterDatabaseStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseStatementSuffix_return
 
HiveParser.alterDatabaseSuffixProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterDatabaseSuffixProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterDatabaseSuffixProperties_return
 
HiveParser.alterIndexStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterIndexStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterIndexStatementSuffix_return
 
HiveParser.alterProtectMode_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterProtectMode_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterProtectMode_return
 
HiveParser.alterProtectModeMode_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterProtectModeMode_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterProtectModeMode_return
 
HiveParser.alterStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatement_return
 
HiveParser.alterStatementChangeColPosition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementChangeColPosition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementChangeColPosition_return
 
HiveParser.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.alterStatementSuffixArchive_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixArchive_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixArchive_return
 
HiveParser.alterStatementSuffixClusterbySortby_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixClusterbySortby_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixClusterbySortby_return
 
HiveParser.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.alterStatementSuffixFileFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixFileFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixFileFormat_return
 
HiveParser.alterStatementSuffixLocation_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixLocation_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixLocation_return
 
HiveParser.alterStatementSuffixProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixProperties_return
 
HiveParser.alterStatementSuffixProtectMode_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixProtectMode_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixProtectMode_return
 
HiveParser.alterStatementSuffixRename_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixRename_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRename_return
 
HiveParser.alterStatementSuffixRenameCol_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixRenameCol_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixRenameCol_return
 
HiveParser.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.alterStatementSuffixTouch_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixTouch_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixTouch_return
 
HiveParser.alterStatementSuffixUnArchive_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterStatementSuffixUnArchive_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterStatementSuffixUnArchive_return
 
HiveParser.alterTableStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterTableStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterTableStatementSuffix_return
 
HiveParser.alterTblPartitionStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterTblPartitionStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterTblPartitionStatement_return
 
HiveParser.alterTblPartitionStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterTblPartitionStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterTblPartitionStatementSuffix_return
 
HiveParser.alterViewStatementSuffix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterViewStatementSuffix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterViewStatementSuffix_return
 
HiveParser.alterViewSuffixProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.alterViewSuffixProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.alterViewSuffixProperties_return
 
HiveParser.analyzeStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.analyzeStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.analyzeStatement_return
 
HiveParser.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.autoRebuild_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.autoRebuild_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.autoRebuild_return
 
HiveParser.body_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.body_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.body_return
 
HiveParser.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.colTypeList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.colTypeList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.colTypeList_return
 
HiveParser.columnName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnName_return
 
HiveParser.columnNameColonType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameColonType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameColonType_return
 
HiveParser.columnNameColonTypeList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameColonTypeList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameColonTypeList_return
 
HiveParser.columnNameComment_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameComment_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameComment_return
 
HiveParser.columnNameCommentList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameCommentList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameCommentList_return
 
HiveParser.columnNameList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameList_return
 
HiveParser.columnNameOrder_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameOrder_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameOrder_return
 
HiveParser.columnNameOrderList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameOrderList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameOrderList_return
 
HiveParser.columnNameType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameType_return
 
HiveParser.columnNameTypeList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnNameTypeList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnNameTypeList_return
 
HiveParser.columnRefOrder_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.columnRefOrder_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.columnRefOrder_return
 
HiveParser.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.createDatabaseStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createDatabaseStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createDatabaseStatement_return
 
HiveParser.createFunctionStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createFunctionStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createFunctionStatement_return
 
HiveParser.createIndexStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createIndexStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createIndexStatement_return
 
HiveParser.createRoleStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createRoleStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createRoleStatement_return
 
HiveParser.createTableStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createTableStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createTableStatement_return
 
HiveParser.createViewStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.createViewStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.createViewStatement_return
 
HiveParser.databaseComment_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.databaseComment_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.databaseComment_return
 
HiveParser.dbProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dbProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dbProperties_return
 
HiveParser.dbPropertiesList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dbPropertiesList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dbPropertiesList_return
 
HiveParser.ddlStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.ddlStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.ddlStatement_return
 
HiveParser.descFuncNames_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.descFuncNames_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.descFuncNames_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.dropDatabaseStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropDatabaseStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropDatabaseStatement_return
 
HiveParser.dropFunctionStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropFunctionStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropFunctionStatement_return
 
HiveParser.dropIndexStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropIndexStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropIndexStatement_return
 
HiveParser.dropRoleStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropRoleStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropRoleStatement_return
 
HiveParser.dropTableStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropTableStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropTableStatement_return
 
HiveParser.dropViewStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.dropViewStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.dropViewStatement_return
 
HiveParser.execStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.execStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.execStatement_return
 
HiveParser.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.expressions_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.expressions_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.expressions_return
 
HiveParser.fileFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.fileFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.fileFormat_return
 
HiveParser.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.grantPrivileges_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.grantPrivileges_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.grantPrivileges_return
 
HiveParser.grantRole_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.grantRole_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.grantRole_return
 
HiveParser.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.havingClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.havingClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.havingClause_return
 
HiveParser.havingCondition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.havingCondition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.havingCondition_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.ifExists_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.ifExists_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.ifExists_return
 
HiveParser.ifNotExists_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.ifNotExists_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.ifNotExists_return
 
HiveParser.indexComment_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexComment_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexComment_return
 
HiveParser.indexProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexProperties_return
 
HiveParser.indexPropertiesList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexPropertiesList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexPropertiesList_return
 
HiveParser.indexPropertiesPrefixed_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexPropertiesPrefixed_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexPropertiesPrefixed_return
 
HiveParser.indexTblName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.indexTblName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.indexTblName_return
 
HiveParser.inOperator_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.inOperator_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.inOperator_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.kwRole_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.kwRole_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.kwRole_return
 
HiveParser.kwUser_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.kwUser_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.kwUser_return
 
HiveParser.lateralView_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.lateralView_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.lateralView_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.lockMode_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.lockMode_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.lockMode_return
 
HiveParser.lockStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.lockStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.lockStatement_return
 
HiveParser.mapType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.mapType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.mapType_return
 
HiveParser.metastoreCheck_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.metastoreCheck_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.metastoreCheck_return
 
HiveParser.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.principalName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.principalName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.principalName_return
 
HiveParser.principalSpecification_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.principalSpecification_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.principalSpecification_return
 
HiveParser.privilegeIncludeColObject_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privilegeIncludeColObject_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeIncludeColObject_return
 
HiveParser.privilegeList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privilegeList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeList_return
 
HiveParser.privilegeObject_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privilegeObject_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeObject_return
 
HiveParser.privilegeType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privilegeType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privilegeType_return
 
HiveParser.privlegeDef_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.privlegeDef_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.privlegeDef_return
 
HiveParser.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.recordReader_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.recordReader_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.recordReader_return
 
HiveParser.recordWriter_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.recordWriter_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.recordWriter_return
 
HiveParser.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.revokePrivileges_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.revokePrivileges_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.revokePrivileges_return
 
HiveParser.revokeRole_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.revokeRole_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.revokeRole_return
 
HiveParser.rowFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.rowFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormat_return
 
HiveParser.rowFormatDelimited_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.rowFormatDelimited_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormatDelimited_return
 
HiveParser.rowFormatSerde_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.rowFormatSerde_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.rowFormatSerde_return
 
HiveParser.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.selectStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectStatement_return
 
HiveParser.selectTrfmClause_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.selectTrfmClause_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.selectTrfmClause_return
 
HiveParser.showGrants_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showGrants_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showGrants_return
 
HiveParser.showRoleGrants_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.showRoleGrants_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.showRoleGrants_return
 
HiveParser.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.structType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.structType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.structType_return
 
HiveParser.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.switchDatabaseStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.switchDatabaseStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.switchDatabaseStatement_return
 
HiveParser.sysFuncNames_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.sysFuncNames_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.sysFuncNames_return
 
HiveParser.tableAlias_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableAlias_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableAlias_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.tableName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableName_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.tableOrPartition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableOrPartition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableOrPartition_return
 
HiveParser.tablePartition_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tablePartition_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tablePartition_return
 
HiveParser.tablePartitionPrefix_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tablePartitionPrefix_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tablePartitionPrefix_return
 
HiveParser.tableProperties_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableProperties_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableProperties_return
 
HiveParser.tablePropertiesList_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tablePropertiesList_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tablePropertiesList_return
 
HiveParser.tablePropertiesPrefixed_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tablePropertiesPrefixed_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tablePropertiesPrefixed_return
 
HiveParser.tableRowFormat_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormat_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormat_return
 
HiveParser.tableRowFormatCollItemsIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormatCollItemsIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatCollItemsIdentifier_return
 
HiveParser.tableRowFormatFieldIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormatFieldIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatFieldIdentifier_return
 
HiveParser.tableRowFormatLinesIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormatLinesIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatLinesIdentifier_return
 
HiveParser.tableRowFormatMapKeysIdentifier_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.tableRowFormatMapKeysIdentifier_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.tableRowFormatMapKeysIdentifier_return
 
HiveParser.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.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.unionType_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.unionType_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.unionType_return
 
HiveParser.uniqueJoinExpr_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.uniqueJoinExpr_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.uniqueJoinExpr_return
 
HiveParser.uniqueJoinSource_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.uniqueJoinSource_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.uniqueJoinSource_return
 
HiveParser.uniqueJoinToken_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.uniqueJoinToken_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.uniqueJoinToken_return
 
HiveParser.unlockStatement_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.unlockStatement_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.unlockStatement_return
 
HiveParser.viewName_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.viewName_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.viewName_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
 
HiveParser.withOption_return - Class in org.apache.hadoop.hive.ql.parse
 
HiveParser.withOption_return() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveParser.withOption_return
 
HivePartitioner<K2,V2> - Interface in org.apache.hadoop.hive.ql.io
Partition keys by their Object.hashCode().
HivePreparedStatement - Class in org.apache.hadoop.hive.jdbc
HivePreparedStatement.
HivePreparedStatement(JdbcSessionState, HiveInterface, String) - Constructor for class org.apache.hadoop.hive.jdbc.HivePreparedStatement
 
HiveQueryResultSet - Class in org.apache.hadoop.hive.jdbc
HiveQueryResultSet.
HiveQueryResultSet(HiveInterface, int) - Constructor for class org.apache.hadoop.hive.jdbc.HiveQueryResultSet
 
HiveQueryResultSet(HiveInterface) - Constructor for class org.apache.hadoop.hive.jdbc.HiveQueryResultSet
 
HIVERCFILE - Static variable in class org.apache.hadoop.hive.cli.CliDriver
 
HiveRecordReader<K extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.hadoop.hive.ql.io
HiveRecordReader is a simple wrapper on RecordReader.
HiveRecordReader(RecordReader) - Constructor for class org.apache.hadoop.hive.ql.io.HiveRecordReader
 
HiveResultSetMetaData - Class in org.apache.hadoop.hive.jdbc
HiveResultSetMetaData.
HiveResultSetMetaData(List<String>, List<String>) - Constructor for class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
HiveSemanticAnalyzerHook - Interface in org.apache.hadoop.hive.ql.parse
HiveSemanticAnalyzerHook allows Hive to be extended with custom logic for semantic analysis of QL statements.
HiveSemanticAnalyzerHookContext - Interface in org.apache.hadoop.hive.ql.parse
Context information provided by Hive to implementations of HiveSemanticAnalyzerHook.
HiveSemanticAnalyzerHookContextImpl - Class in org.apache.hadoop.hive.ql.parse
 
HiveSemanticAnalyzerHookContextImpl() - Constructor for class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
HiveSequenceFileOutputFormat - 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
ThriftHiveProcessorFactory.
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, int, String) - Constructor for exception org.apache.hadoop.hive.service.HiveServerException
 
HiveServerException(HiveServerException) - Constructor for exception org.apache.hadoop.hive.service.HiveServerException
Performs a deep copy on other.
HiveServerException._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HiveStatement - Class in org.apache.hadoop.hive.jdbc
HiveStatement.
HiveStatement(JdbcSessionState, HiveInterface) - Constructor for class org.apache.hadoop.hive.jdbc.HiveStatement
 
HiveStorageHandler - Interface in org.apache.hadoop.hive.ql.metadata
HiveStorageHandler defines a pluggable interface for adding new storage handlers to Hive.
HiveStoragePredicateHandler - Interface in org.apache.hadoop.hive.ql.metadata
HiveStoragePredicateHandler is an optional companion to HiveStorageHandler; it should only be implemented by handlers which support decomposition of predicates being pushed down into table scans.
HiveStoragePredicateHandler.DecomposedPredicate - Class in org.apache.hadoop.hive.ql.metadata
Struct class for returning multiple values from decomposePredicate.
HiveStoragePredicateHandler.DecomposedPredicate() - Constructor for class org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler.DecomposedPredicate
 
hiveTypeToSqlType(String) - Static method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
Convert hive types to sql types.
HiveUtils - Class in org.apache.hadoop.hive.ql.metadata
General collection of helper functions.
hm - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
hm - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.TaskInfo
 
Hook - Interface in org.apache.hadoop.hive.ql.hooks
The new interface for all the pre execute hooks and post execute hooks
hook - Variable in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
 
HookContext - Class in org.apache.hadoop.hive.ql.hooks
Hook Context keeps all the necessary information for all the hooks.
HookContext(QueryPlan, HiveConf) - Constructor for class org.apache.hadoop.hive.ql.hooks.HookContext
 
HWIAuth - Class in org.apache.hadoop.hive.hwi
Represents an authenticated user.
HWIAuth() - Constructor for class org.apache.hadoop.hive.hwi.HWIAuth
 
HWIContextListener - Class in org.apache.hadoop.hive.hwi
After getting a contextInitialized event this component starts an instance of the HiveSessionManager.
HWIContextListener() - Constructor for class org.apache.hadoop.hive.hwi.HWIContextListener
 
HWIException - Exception in org.apache.hadoop.hive.hwi
HWIException.
HWIException() - Constructor for exception org.apache.hadoop.hive.hwi.HWIException
 
HWIException(String) - Constructor for exception org.apache.hadoop.hive.hwi.HWIException
Specify an error String with the Exception.
HWIException(Throwable) - Constructor for exception org.apache.hadoop.hive.hwi.HWIException
Wrap an Exception in HWIException.
HWIException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.hwi.HWIException
Specify an error String and wrap an Exception in HWIException.
HWIServer - Class in org.apache.hadoop.hive.hwi
This is the entry point for HWI.
HWIServer(String[]) - Constructor for class org.apache.hadoop.hive.hwi.HWIServer
 
HWISessionItem - Class in org.apache.hadoop.hive.hwi
HWISessionItem can be viewed as a wrapper for a Hive shell.
HWISessionItem(HWIAuth, String) - Constructor for class org.apache.hadoop.hive.hwi.HWISessionItem
Creates an instance of WebSessionItem, sets status to NEW.
HWISessionItem.WebSessionItemStatus - Enum in org.apache.hadoop.hive.hwi
Represents the state a session item can be in.
HWISessionManager - Class in org.apache.hadoop.hive.hwi
HiveSessionManager is a Runnable started inside a web application context.
HWISessionManager() - Constructor for class org.apache.hadoop.hive.hwi.HWISessionManager
 

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
 
idx - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
ifExists() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
Streams to read/write from.
inBuf - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
incCurJobNo(int) - Method in class org.apache.hadoop.hive.ql.DriverContext
 
Include() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
incrCounter(String, long) - Method in class org.apache.hadoop.hive.ql.exec.Operator
this is called in operators in map or reduce tasks.
increaseNumRows(long) - Method in class org.apache.hadoop.hive.ql.exec.Stat
 
incrementCounter(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
incrementCounter(String, long) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
INDENT - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
Index - Class in org.apache.hadoop.hive.metastore.api
 
Index() - Constructor for class org.apache.hadoop.hive.metastore.api.Index
 
Index(String, String, String, String, int, int, String, StorageDescriptor, Map<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.Index
 
Index(Index) - Constructor for class org.apache.hadoop.hive.metastore.api.Index
Performs a deep copy on other.
index - Variable in class org.apache.hadoop.hive.ql.hooks.LineageInfo
The map contains an index from the (datacontainer, columnname) to the dependency vector for that tuple.
INDEX - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
index - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
An index into what column we're on.
Index._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
INDEX_TABLE_CREATETIME - Static variable in class org.apache.hadoop.hive.ql.index.HiveIndex
 
IndexAlreadyExistsException - Exception in org.apache.hadoop.hive.metastore.api
 
IndexAlreadyExistsException() - Constructor for exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
IndexAlreadyExistsException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
IndexAlreadyExistsException(IndexAlreadyExistsException) - Constructor for exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
Performs a deep copy on other.
IndexAlreadyExistsException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
indexComment() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
IndexMetadataChangeTask - Class in org.apache.hadoop.hive.ql.index.compact
 
IndexMetadataChangeTask() - Constructor for class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeTask
 
IndexMetadataChangeWork - Class in org.apache.hadoop.hive.ql.index.compact
 
IndexMetadataChangeWork() - Constructor for class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeWork
 
IndexMetadataChangeWork(HashMap<String, String>, String, String) - Constructor for class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeWork
 
IndexPredicateAnalyzer - Class in org.apache.hadoop.hive.ql.index
IndexPredicateAnalyzer decomposes predicates, separating the parts which can be satisfied by an index from the parts which cannot.
IndexPredicateAnalyzer() - Constructor for class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
 
indexProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
indexPropertiesList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
indexPropertiesPrefixed() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
IndexSearchCondition - Class in org.apache.hadoop.hive.ql.index
IndexSearchCondition represents an individual search condition found by IndexPredicateAnalyzer.
IndexSearchCondition(ExprNodeColumnDesc, String, ExprNodeConstantDesc, ExprNodeDesc) - Constructor for class org.apache.hadoop.hive.ql.index.IndexSearchCondition
Constructs a search condition, which takes the form
indexTblName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
init() - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
init() - Method in class org.apache.hadoop.hive.ql.Driver
 
init(String, JobConf) - Method in interface org.apache.hadoop.hive.ql.exec.errors.ErrorHeuristic
Initialize this error heuristic.
init(String, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.errors.MapAggrMemErrorHeuristic
 
init(String, JobConf) - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
init() - 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() - Method in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
init() - Method in interface org.apache.hadoop.hive.ql.processors.CommandProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.DeleteResourceProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.DfsProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.processors.SetProcessor
 
init() - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
init(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
init(Configuration) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
 
init(Configuration) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
init(Configuration) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
init(Configuration) - Method in interface org.apache.hadoop.hive.ql.stats.StatsPublisher
This method does the necessary one-time initializations, possibly creating the tables and database (if not exist).
init(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.GenericUDAFCollectSet.GenericUDAFMkSetEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Initialize the evaluator.
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator
 
init(GenericUDAFEvaluator.Mode, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.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.UDAFPercentile.PercentileLongArrayEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxDoubleEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxFloatEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxIntEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxLongEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxShortEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxStringEvaluator
 
init() - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
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(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyUnion
Set the row data for this LazyUnion.
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(List<ObjectInspector>, byte, Text, boolean, byte) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
init(List<ObjectInspector>, byte, Text) - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryArray
Set the row data for this LazyBinaryArray.
init(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.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(ByteArrayRef, int, int) - Method in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryVoid
 
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
 
initConf() - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
initEvaluators(ExprNodeEvaluator[], ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.Operator
Initialize an array of ExprNodeEvaluator and return the result ObjectInspectors.
initEvaluators(ExprNodeEvaluator[], int, int, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.Operator
Initialize an array of ExprNodeEvaluator from start, for specified length and return the result ObjectInspectors.
initEvaluatorsAndReturnStruct(ExprNodeEvaluator[], List<String>, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.Operator
Initialize an array of ExprNodeEvaluator and put the return values into a StructObjectInspector with integer field names.
initEvaluatorsAndReturnStruct(ExprNodeEvaluator[], List<List<Integer>>, List<String>, int, ObjectInspector) - Static method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
Initializes array of ExprNodeEvaluator.
initFiles - Variable in class org.apache.hadoop.hive.cli.CliSessionState
-i option if any that the session has been invoked with.
initHiveLog4j() - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
initialize(InputStream, Configuration, Properties) - Method in class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
initialize(HiveConf, QueryPlan, DriverContext) - 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.ExprNodeGenericFuncEvaluator
 
initialize(ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.ExprNodeNullEvaluator
 
initialize(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
initialize(Configuration, ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Initializes operators only if all parents have been initialized.
initialize(InputStream, Configuration, Properties) - Method in interface org.apache.hadoop.hive.ql.exec.RecordReader
 
initialize(OutputStream, Configuration) - Method in interface org.apache.hadoop.hive.ql.exec.RecordWriter
 
initialize(HiveConf, QueryPlan, DriverContext) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
initialize(InputStream, Configuration, Properties) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
initialize(OutputStream, Configuration) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordWriter
 
initialize(Class, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.CollectionPersistenceDelegate
 
initialize(Class<?>, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.ListDelegate
 
initialize(Class<?>, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.MapDelegate
 
initialize(Class<?>, Object, Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.SetDelegate
 
initialize(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.GenericUDFArray
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFArrayContains
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCase
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFCoalesce
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFConcatWS
 
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.GenericUDFField
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFHash
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIf
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIn
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFIndex
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.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.GenericUDFMap
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPAnd
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNot
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNotNull
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPNull
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFOPOr
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFReflect
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSentences
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSize
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFSplit
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStringToMap
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFStruct
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestGetJavaBoolean
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestGetJavaString
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFTestTranslate
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFUnion
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFWhen
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Initialize this GenericUDTF.
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
initialize(int, int, int) - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Sets the 'k' and 'pf' parameters.
initialize(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.udf.xml.GenericUDFXPath
 
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 class org.apache.hadoop.hive.serde2.TestSerDe
 
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.
initializeCounters() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
initialized - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
initializeLocalWork(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
initializeLocalWork(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
initializeMapredLocalWork(MapJoinDesc, Configuration, MapredLocalWork, Log) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
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.HashTableDummyOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
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.SMBMapJoinOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
initializeOp(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
UnionOperator will transform the input rows if the inputObjInspectors from different parents are different.
initiliaze(Configuration) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
initilizePersistentHash(String) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
initIOContext(long, boolean, String) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
initIOContext(FileSplit, JobConf, Class) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
initIOContext(FileSplit, JobConf, Class, RecordReader) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
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
 
initMapJoinPlan(Operator<? extends Serializable>, GenMRProcContext, boolean, boolean, boolean, int, boolean) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
Initialize the current plan by adding it to root tasks.
initNextRecordReader() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
Get the record reader for the next chunk in this BucketizedHiveRecordReader.
initOperatorId() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
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.
initSerdeParams(Configuration, Properties, String) - Static method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
initSpillTables(JoinDesc, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
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.
InnerStruct._Fields - Enum in org.apache.hadoop.hive.serde.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
innerTransport - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The transport being wrapped.
inOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
inputFileChanged() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
For CompbineFileInputFormat, the mapper's input file will be changed on the fly, and the input file name is passed to jobConf by shims/initNextRecordReader.
inputFormat - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
InputFormatChecker - Interface in org.apache.hadoop.hive.ql.io
Check for validity of the input files.
inputFormatClassName - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
inputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
inputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Returns the inputFormat class name for the i-th chunk.
inputFormatClassName() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
inputFormats - Static variable in class org.apache.hadoop.hive.ql.io.HiveInputFormat
A cache of InputFormat instances.
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
 
inputOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
inputRows - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
inputs - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
ReadEntitites that are passed to the hooks.
inputs - Variable in class org.apache.hadoop.hive.ql.plan.DDLWork
ReadEntitites that are passed to the hooks.
inputs - Variable in class org.apache.hadoop.hive.ql.plan.MoveWork
ReadEntitites that are passed to the hooks.
InputSignature - Class in org.apache.hadoop.hive.ql.parse
The input signature of a function or operator.
InputSignature(String) - Constructor for class org.apache.hadoop.hive.ql.parse.InputSignature
 
InputSignature(String, TypeInfo...) - Constructor for class org.apache.hadoop.hive.ql.parse.InputSignature
 
InputSignature(String, Class<?>...) - Constructor for class org.apache.hadoop.hive.ql.parse.InputSignature
 
inputSplits - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
inputStream - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
inSample(Object) - Method in class org.apache.hadoop.hive.ql.metadata.Sample
Given an arbitrary object, determine if it falls within this sample.
insertAfter(DCLLItem) - Method in class org.apache.hadoop.hive.ql.exec.persistence.DCLLItem
Add v as the previous of the current list item.
insertBefore(DCLLItem) - Method in class org.apache.hadoop.hive.ql.exec.persistence.DCLLItem
Add v as the previous of the current list item.
insertClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
insertRow() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.CollectionPersistenceDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.EnumDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.ListDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.MapDelegate
 
instantiate(Object, Encoder) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.SetDelegate
 
INT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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.
IntString._Fields - Enum in org.apache.hadoop.hive.serde2.thrift.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
intTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
intTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
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
 
InvalidObjectException - Exception in org.apache.hadoop.hive.metastore.api
 
InvalidObjectException() - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
InvalidObjectException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
InvalidObjectException(InvalidObjectException) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
Performs a deep copy on other.
InvalidObjectException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InvalidOperationException - Exception in org.apache.hadoop.hive.metastore.api
 
InvalidOperationException() - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
InvalidOperationException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
InvalidOperationException(InvalidOperationException) - Constructor for exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
Performs a deep copy on other.
InvalidOperationException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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(String, Object[], String[]) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
invoke(Method, Object, Object...) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
IOContext - Class in org.apache.hadoop.hive.ql.io
IOContext basically contains the position information of the current key/value.
IOContext() - Constructor for class org.apache.hadoop.hive.ql.io.IOContext
 
ioi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
ioi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
IOPrepareCache - Class in org.apache.hadoop.hive.ql.io
IOPrepareCache is used to cache pre-query io-related objects.
IOPrepareCache() - Constructor for class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
iprot_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
IS_ARCHIVED - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
isAbort() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapper
 
isAbort(long, SessionState.LogHelper) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
isActiveTransaction() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
isAfterLast() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
isAllColumns() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFParameterInfo
Returns true if the UDAF invocation was done via the wildcard syntax FUNCTION(*).
isAllColumns() - Method in class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
 
isAnalyzeCommand() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isArchived(Partition) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
isAutoIncrement(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isBeforeFirst() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
isBlockPointer() - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
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.HiveBaseResultSet
 
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.HiveStatement
 
isComplete() - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
isCompressed() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
isCompressed() - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
isCompressed - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
isCompressedRCFile() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
 
isCTAS() - Method in class org.apache.hadoop.hive.ql.parse.QB
Whether this QB is for a CREATE-TABLE-AS-SELECT.
isCurrency(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
isDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
isDeferredRebuild() - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
isDefinitelyWritable(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
isDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
isDeterministic(GenericUDF) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether a GenericUDF is deterministic or not.
isDeterministic() - Method in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
isDir(Path) - Method in class org.apache.hadoop.hive.metastore.Warehouse
 
isDistinct() - Method in interface org.apache.hadoop.hive.ql.udf.generic.GenericUDAFParameterInfo
Returns true if the UDAF invocation was qualified with DISTINCT keyword.
isDistinct() - Method in class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
 
isdone - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
isDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
isEligibleForLocalMode(HiveConf, ContentSummary, int) - Static method in class org.apache.hadoop.hive.ql.exec.MapRedTask
Find out if a job can be run in local mode based on it's characteristics
isEmptyPath(JobConf, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
isEmptyTable() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
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.LazyUnionObjectInspector
 
isEscaped() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyStringObjectInspector
 
isExt() - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
isExt() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
isExt() - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
isExtended() - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
isExternal() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
isExternal() - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
isExternalTable(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Determines whether a table is an external table.
isFileContentEqual(File, File) - Method in class org.apache.hadoop.hive.hwi.TestHWISessionManager
 
isFiltered(Object, List<ExprNodeEvaluator>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
Returns true if the row does not pass through filters.
isFiltered(Object, List<ExprNodeEvaluator>, List<ObjectInspector>) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
Returns true if the row does not pass through filters.
isFirst() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
isFollowedByGroupBy() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
isFormatted() - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
isFormatted() - Method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
isGatheringStats() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
isGatherStats() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isGatherStats() - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
isGenericUDAF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isGenericUDF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isGenericUDTF() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
 
isGoOn() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
isGrant_option() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
isGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
isGrantOption() - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
isGrantOption() - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
isHandleSkewJoin() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
isHidden() - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
isHiddenVirtualCol() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
isIndexTable(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
isInitialized() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Returns true if the 'k' and 'pf' parameters have been set.
isInitialized() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
isInitialized() - Method in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
isInsertToTable() - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
isInvalid() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
isJobPreparing(RunningJob) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Return true if the job has not switched to RUNNING state yet and is still in PREP state
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.HiveBaseResultSet
 
isLastColumnTakesRest() - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe.SerDeParameters
 
isLaunchable(Task<? extends Serializable>) - Static method in class org.apache.hadoop.hive.ql.DriverContext
Checks if a task can be launched.
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
 
isLocalFileSystem() - Method in class org.apache.hadoop.hive.ql.io.PerformTestRCFileAndSeqFile
 
isLocalMode() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isLocalOnlyExecutionMode() - Method in class org.apache.hadoop.hive.ql.Context
Does Hive wants to run tasks entirely on the local machine (where the query is being compiled)? Today this translates into running hadoop jobs locally
isLogInfoEnabled - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
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
 
isMapperCannotSpanPartns() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
isMapRedLocalTask() - Method in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
isMapRedLocalTask() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
isMapRedTask() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
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 for intermediate data
isMultiFileSpray() - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
isNative() - Method in class org.apache.hadoop.hive.ql.exec.FunctionInfo
Native functions cannot be unregistered.
isNeedLockMgr() - Method in class org.apache.hadoop.hive.ql.Context
 
isNonNative() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isNonNative() - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
isNonNativeTable(Table) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
isNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
isNoOuterJoin() - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
isNullable(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isOffline() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
isOffline() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isOpAnd(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "and".
isOpAndOrNot(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "and", "or", "not".
isOperator() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
isOpNot(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "not".
isOpOr(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "or".
isOpPositive(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns whether the exprNodeDesc is a node of "positive".
isPartition() - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
Returns true in case this data container is a partition.
isPartitioned() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
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.
isProtectModeEnable() - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
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
 
isReady() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Returns true if this histogram object has been initialized by calling merge() or allocate().
isRealThrift - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldList
Indicates whether fields can be out of order or missing.
isRedundantConversionFunction(ASTNode, boolean, ArrayList<ExprNodeDesc>) - Static method in class org.apache.hadoop.hive.ql.parse.TypeCheckProcFactory.DefaultExprProcessor
 
isRepairPartitions() - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
isReverseOrder - Variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
isRunnable() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
isRunning() - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
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.ExprNodeGenericFuncDesc
 
isSame(Object) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeNullDesc
 
isSearchable(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
isSecureShimImpl() - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Return true if the Shim is based on Hadoop Security APIs.
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(AlreadyExistsException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ConfigValSecurityException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Database._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(FieldSchema._Fields) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(HiveObjectPrivilege._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(HiveObjectRef._Fields) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Index._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(IndexAlreadyExistsException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(InvalidObjectException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(InvalidOperationException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(MetaException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(NoSuchObjectException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Order._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Order
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Partition._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(PrincipalPrivilegeSet._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(PrivilegeBag._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(PrivilegeGrantInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Role._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Role
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Schema._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Schema
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(SerDeInfo._Fields) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(StorageDescriptor._Fields) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Table._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_index_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_index_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.add_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_index_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_index_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.alter_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.append_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.cancel_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.cancel_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.create_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_index_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_index_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.drop_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_all_databases_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_all_databases_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_all_tables_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_all_tables_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_config_value_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_config_value_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_database_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_database_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_databases_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_databases_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_fields_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_fields_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_index_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_index_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_index_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_index_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_indexes_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_indexes_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_by_name_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_by_name_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_names_ps_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_names_ps_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partition_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_by_filter_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_by_filter_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_ps_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_ps_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_with_auth_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_partitions_with_auth_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_privilege_set_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_privilege_set_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_role_names_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_role_names_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_schema_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_schema_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_table_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_tables_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_tables_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_type_all_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_type_all_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_type_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.get_type_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.grant_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.list_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.list_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.list_roles_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.list_roles_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_to_spec_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_to_spec_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_to_vals_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.partition_name_to_vals_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.renew_delegation_token_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.renew_delegation_token_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.revoke_privileges_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.revoke_privileges_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.revoke_role_args._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHiveMetastore.revoke_role_result._Fields) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Type._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(UnknownDBException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(UnknownTableException._Fields) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Version._Fields) - Method in class org.apache.hadoop.hive.metastore.api.Version
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Adjacency._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Graph._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Operator._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Query._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(QueryPlan._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Stage._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Task._Fields) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(InnerStruct._Fields) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftTestObj._Fields) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Complex._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(IntString._Fields) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(HiveClusterStatus._Fields) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(HiveServerException._Fields) - Method in exception org.apache.hadoop.hive.service.HiveServerException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.execute_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.execute_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.fetchAll_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.fetchAll_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.fetchN_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.fetchN_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.fetchOne_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.fetchOne_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.getClusterStatus_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.getClusterStatus_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.getQueryPlan_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.getQueryPlan_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.getSchema_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.getSchema_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.getThriftSchema_args._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ThriftHive.getThriftSchema_result._Fields) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSetAdjacencyList() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
Returns true if field adjacencyList is set (has been asigned a value) and false otherwise
isSetAdjacencyType() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
Returns true if field adjacencyType is set (has been asigned a value) and false otherwise
isSetAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field aint is set (has been asigned a value) and false otherwise
isSetAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field aString is set (has been asigned a value) and false otherwise
isSetBase_tbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field base_tbl_name is set (has been asigned a value) and false otherwise
isSetBucketCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field bucketCols is set (has been asigned a value) and false otherwise
isSetChildren() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
Returns true if field children is set (has been asigned a value) and false otherwise
isSetCol() - Method in class org.apache.hadoop.hive.metastore.api.Order
Returns true if field col is set (has been asigned a value) and false otherwise
isSetCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field cols is set (has been asigned a value) and false otherwise
isSetColumnName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field columnName is set (has been asigned a value) and false otherwise
isSetComment() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
Returns true if field comment is set (has been asigned a value) and false otherwise
isSetComments() - Method in class org.apache.hadoop.hive.metastore.api.Version
Returns true if field comments is set (has been asigned a value) and false otherwise
isSetCompressed() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field compressed is set (has been asigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field createTime is set (has been asigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field createTime is set (has been asigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field createTime is set (has been asigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Role
Returns true if field createTime is set (has been asigned a value) and false otherwise
isSetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field createTime is set (has been asigned a value) and false otherwise
isSetDatabase() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
Returns true if field database is set (has been asigned a value) and false otherwise
isSetDb() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
Returns true if field db is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
Returns true if field db_name is set (has been asigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field dbName is set (has been asigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field dbName is set (has been asigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field dbName is set (has been asigned a value) and false otherwise
isSetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field dbName is set (has been asigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
Returns true if field dbname is set (has been asigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field dbname is set (has been asigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Returns true if field dbname is set (has been asigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Returns true if field dbname is set (has been asigned a value) and false otherwise
isSetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
Returns true if field dbname is set (has been asigned a value) and false otherwise
isSetDefaultValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
Returns true if field defaultValue is set (has been asigned a value) and false otherwise
isSetDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field deferredRebuild is set (has been asigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Returns true if field deleteData is set (has been asigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field deleteData is set (has been asigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field deleteData is set (has been asigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field deleteData is set (has been asigned a value) and false otherwise
isSetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Returns true if field deleteData is set (has been asigned a value) and false otherwise
isSetDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field description is set (has been asigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field done is set (has been asigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field done is set (has been asigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Returns true if field done is set (has been asigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field done is set (has been asigned a value) and false otherwise
isSetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field done is set (has been asigned a value) and false otherwise
isSetErrorCode() - Method in exception org.apache.hadoop.hive.service.HiveServerException
Returns true if field errorCode is set (has been asigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
Returns true if field ex is set (has been asigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
Returns true if field ex is set (has been asigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
Returns true if field ex is set (has been asigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
Returns true if field ex is set (has been asigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
Returns true if field ex is set (has been asigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
Returns true if field ex is set (has been asigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
Returns true if field ex is set (has been asigned a value) and false otherwise
isSetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
Returns true if field ex is set (has been asigned a value) and false otherwise
isSetField0() - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
Returns true if field field0 is set (has been asigned a value) and false otherwise
isSetField1() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
Returns true if field field1 is set (has been asigned a value) and false otherwise
isSetField2() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
Returns true if field field2 is set (has been asigned a value) and false otherwise
isSetField3() - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
Returns true if field field3 is set (has been asigned a value) and false otherwise
isSetFields() - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field fields is set (has been asigned a value) and false otherwise
isSetFieldSchemas() - Method in class org.apache.hadoop.hive.metastore.api.Schema
Returns true if field fieldSchemas is set (has been asigned a value) and false otherwise
isSetFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field filter is set (has been asigned a value) and false otherwise
isSetGrant_option() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field grant_option is set (has been asigned a value) and false otherwise
isSetGrantInfo() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field grantInfo is set (has been asigned a value) and false otherwise
isSetGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field grantOption is set (has been asigned a value) and false otherwise
isSetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field grantor is set (has been asigned a value) and false otherwise
isSetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field grantor is set (has been asigned a value) and false otherwise
isSetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field grantorType is set (has been asigned a value) and false otherwise
isSetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field grantorType is set (has been asigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field group_names is set (has been asigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field group_names is set (has been asigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field group_names is set (has been asigned a value) and false otherwise
isSetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Returns true if field group_names is set (has been asigned a value) and false otherwise
isSetGroupPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Returns true if field groupPrivileges is set (has been asigned a value) and false otherwise
isSetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field hiveObject is set (has been asigned a value) and false otherwise
isSetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Returns true if field hiveObject is set (has been asigned a value) and false otherwise
isSetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Returns true if field hiveObject is set (has been asigned a value) and false otherwise
isSetIdx_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field idx_name is set (has been asigned a value) and false otherwise
isSetIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field index_name is set (has been asigned a value) and false otherwise
isSetIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Returns true if field index_name is set (has been asigned a value) and false otherwise
isSetIndex_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
Returns true if field index_table is set (has been asigned a value) and false otherwise
isSetIndexHandlerClass() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field indexHandlerClass is set (has been asigned a value) and false otherwise
isSetIndexName() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field indexName is set (has been asigned a value) and false otherwise
isSetIndexTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field indexTableName is set (has been asigned a value) and false otherwise
isSetInputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field inputFormat is set (has been asigned a value) and false otherwise
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field lastAccessTime is set (has been asigned a value) and false otherwise
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field lastAccessTime is set (has been asigned a value) and false otherwise
isSetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field lastAccessTime is set (has been asigned a value) and false otherwise
isSetLint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field lint is set (has been asigned a value) and false otherwise
isSetLintString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field lintString is set (has been asigned a value) and false otherwise
isSetLocation() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field location is set (has been asigned a value) and false otherwise
isSetLocationUri() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field locationUri is set (has been asigned a value) and false otherwise
isSetLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field lString is set (has been asigned a value) and false otherwise
isSetMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field mapTasks is set (has been asigned a value) and false otherwise
isSetMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Returns true if field max_indexes is set (has been asigned a value) and false otherwise
isSetMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Returns true if field max_indexes is set (has been asigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Returns true if field max_parts is set (has been asigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field max_parts is set (has been asigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Returns true if field max_parts is set (has been asigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field max_parts is set (has been asigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field max_parts is set (has been asigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field max_parts is set (has been asigned a value) and false otherwise
isSetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field max_parts is set (has been asigned a value) and false otherwise
isSetMaxMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field maxMapTasks is set (has been asigned a value) and false otherwise
isSetMaxReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field maxReduceTasks is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.hadoop.hive.service.HiveServerException
Returns true if field message is set (has been asigned a value) and false otherwise
isSetMStringString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
Returns true if field mStringString is set (has been asigned a value) and false otherwise
isSetMyint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
Returns true if field myint is set (has been asigned a value) and false otherwise
isSetMyString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
Returns true if field myString is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field name is set (has been asigned a value) and false otherwise
isSetNew_idx() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Returns true if field new_idx is set (has been asigned a value) and false otherwise
isSetNew_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
Returns true if field new_index is set (has been asigned a value) and false otherwise
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
Returns true if field new_part is set (has been asigned a value) and false otherwise
isSetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Returns true if field new_part is set (has been asigned a value) and false otherwise
isSetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Returns true if field new_tbl is set (has been asigned a value) and false otherwise
isSetNode() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
Returns true if field node is set (has been asigned a value) and false otherwise
isSetNodeType() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
Returns true if field nodeType is set (has been asigned a value) and false otherwise
isSetNumBuckets() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field numBuckets is set (has been asigned a value) and false otherwise
isSetNumRows() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
Returns true if field numRows is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
Returns true if field o1 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Returns true if field o2 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field o3 is set (has been asigned a value) and false otherwise
isSetO4() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Returns true if field o4 is set (has been asigned a value) and false otherwise
isSetObjectName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field objectName is set (has been asigned a value) and false otherwise
isSetObjectType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field objectType is set (has been asigned a value) and false otherwise
isSetOperatorAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field operatorAttributes is set (has been asigned a value) and false otherwise
isSetOperatorCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field operatorCounters is set (has been asigned a value) and false otherwise
isSetOperatorGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field operatorGraph is set (has been asigned a value) and false otherwise
isSetOperatorId() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field operatorId is set (has been asigned a value) and false otherwise
isSetOperatorList() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field operatorList is set (has been asigned a value) and false otherwise
isSetOperatorType() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field operatorType is set (has been asigned a value) and false otherwise
isSetOrder() - Method in class org.apache.hadoop.hive.metastore.api.Order
Returns true if field order is set (has been asigned a value) and false otherwise
isSetOrigTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field origTableName is set (has been asigned a value) and false otherwise
isSetOutputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field outputFormat is set (has been asigned a value) and false otherwise
isSetOwner() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field owner is set (has been asigned a value) and false otherwise
isSetOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Role
Returns true if field ownerName is set (has been asigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field parameters is set (has been asigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field parameters is set (has been asigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field parameters is set (has been asigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
Returns true if field parameters is set (has been asigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field parameters is set (has been asigned a value) and false otherwise
isSetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field parameters is set (has been asigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Returns true if field part_name is set (has been asigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field part_name is set (has been asigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Returns true if field part_name is set (has been asigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
Returns true if field part_name is set (has been asigned a value) and false otherwise
isSetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
Returns true if field part_name is set (has been asigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Returns true if field part_vals is set (has been asigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field part_vals is set (has been asigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Returns true if field part_vals is set (has been asigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field part_vals is set (has been asigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field part_vals is set (has been asigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field part_vals is set (has been asigned a value) and false otherwise
isSetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field part_vals is set (has been asigned a value) and false otherwise
isSetPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field partitionKeys is set (has been asigned a value) and false otherwise
isSetPartValues() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
Returns true if field partValues is set (has been asigned a value) and false otherwise
isSetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
Returns true if field pattern is set (has been asigned a value) and false otherwise
isSetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
Returns true if field pattern is set (has been asigned a value) and false otherwise
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field principal_name is set (has been asigned a value) and false otherwise
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Returns true if field principal_name is set (has been asigned a value) and false otherwise
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
Returns true if field principal_name is set (has been asigned a value) and false otherwise
isSetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Returns true if field principal_name is set (has been asigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field principal_type is set (has been asigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Returns true if field principal_type is set (has been asigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
Returns true if field principal_type is set (has been asigned a value) and false otherwise
isSetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Returns true if field principal_type is set (has been asigned a value) and false otherwise
isSetPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field principalName is set (has been asigned a value) and false otherwise
isSetPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
Returns true if field principalType is set (has been asigned a value) and false otherwise
isSetPrivilege() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Returns true if field privilege is set (has been asigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Database
Returns true if field privileges is set (has been asigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field privileges is set (has been asigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
Returns true if field privileges is set (has been asigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field privileges is set (has been asigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
Returns true if field privileges is set (has been asigned a value) and false otherwise
isSetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
Returns true if field privileges is set (has been asigned a value) and false otherwise
isSetProperties() - Method in class org.apache.hadoop.hive.metastore.api.Schema
Returns true if field properties is set (has been asigned a value) and false otherwise
isSetQueries() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Returns true if field queries is set (has been asigned a value) and false otherwise
isSetQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
Returns true if field query is set (has been asigned a value) and false otherwise
isSetQueryAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field queryAttributes is set (has been asigned a value) and false otherwise
isSetQueryCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field queryCounters is set (has been asigned a value) and false otherwise
isSetQueryId() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field queryId is set (has been asigned a value) and false otherwise
isSetQueryType() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field queryType is set (has been asigned a value) and false otherwise
isSetReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field reduceTasks is set (has been asigned a value) and false otherwise
isSetRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
Returns true if field renewer_kerberos_principal_name is set (has been asigned a value) and false otherwise
isSetRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
Returns true if field renewer_kerberos_principal_name is set (has been asigned a value) and false otherwise
isSetRetention() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field retention is set (has been asigned a value) and false otherwise
isSetRole() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
Returns true if field role is set (has been asigned a value) and false otherwise
isSetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
Returns true if field role_name is set (has been asigned a value) and false otherwise
isSetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Returns true if field role_name is set (has been asigned a value) and false otherwise
isSetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Returns true if field role_name is set (has been asigned a value) and false otherwise
isSetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.Role
Returns true if field roleName is set (has been asigned a value) and false otherwise
isSetRolePrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Returns true if field rolePrivileges is set (has been asigned a value) and false otherwise
isSetRoots() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
Returns true if field roots is set (has been asigned a value) and false otherwise
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.Index
Returns true if field sd is set (has been asigned a value) and false otherwise
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field sd is set (has been asigned a value) and false otherwise
isSetSd() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field sd is set (has been asigned a value) and false otherwise
isSetSerdeInfo() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field serdeInfo is set (has been asigned a value) and false otherwise
isSetSerializationLib() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
Returns true if field serializationLib is set (has been asigned a value) and false otherwise
isSetSortCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
Returns true if field sortCols is set (has been asigned a value) and false otherwise
isSetSQLState() - Method in exception org.apache.hadoop.hive.service.HiveServerException
Returns true if field SQLState is set (has been asigned a value) and false otherwise
isSetStageAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field stageAttributes is set (has been asigned a value) and false otherwise
isSetStageCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field stageCounters is set (has been asigned a value) and false otherwise
isSetStageGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field stageGraph is set (has been asigned a value) and false otherwise
isSetStageId() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field stageId is set (has been asigned a value) and false otherwise
isSetStageList() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field stageList is set (has been asigned a value) and false otherwise
isSetStageType() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field stageType is set (has been asigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
Returns true if field started is set (has been asigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
Returns true if field started is set (has been asigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Returns true if field started is set (has been asigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field started is set (has been asigned a value) and false otherwise
isSetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field started is set (has been asigned a value) and false otherwise
isSetState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field state is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
Returns true if field table_name is set (has been asigned a value) and false otherwise
isSetTable_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
Returns true if field table_name is set (has been asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field tableName is set (has been asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field tableName is set (has been asigned a value) and false otherwise
isSetTableType() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field tableType is set (has been asigned a value) and false otherwise
isSetTaskAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field taskAttributes is set (has been asigned a value) and false otherwise
isSetTaskCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field taskCounters is set (has been asigned a value) and false otherwise
isSetTaskId() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field taskId is set (has been asigned a value) and false otherwise
isSetTaskList() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
Returns true if field taskList is set (has been asigned a value) and false otherwise
isSetTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
Returns true if field taskTrackers is set (has been asigned a value) and false otherwise
isSetTaskType() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
Returns true if field taskType is set (has been asigned a value) and false otherwise
isSetTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
Returns true if field tbl is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
Returns true if field tbl_name is set (has been asigned a value) and false otherwise
isSetToken_signature() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
Returns true if field token_signature is set (has been asigned a value) and false otherwise
isSetToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
Returns true if field token_str_form is set (has been asigned a value) and false otherwise
isSetToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
Returns true if field token_str_form is set (has been asigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
Returns true if field type is set (has been asigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
Returns true if field type is set (has been asigned a value) and false otherwise
isSetType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
Returns true if field type is set (has been asigned a value) and false otherwise
isSetType1() - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field type1 is set (has been asigned a value) and false otherwise
isSetType2() - Method in class org.apache.hadoop.hive.metastore.api.Type
Returns true if field type2 is set (has been asigned a value) and false otherwise
isSetUnderscore_int() - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
Returns true if field underscore_int is set (has been asigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Returns true if field user_name is set (has been asigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Returns true if field user_name is set (has been asigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Returns true if field user_name is set (has been asigned a value) and false otherwise
isSetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Returns true if field user_name is set (has been asigned a value) and false otherwise
isSetUserPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Returns true if field userPrivileges is set (has been asigned a value) and false otherwise
isSetValues() - Method in class org.apache.hadoop.hive.metastore.api.Partition
Returns true if field values is set (has been asigned a value) and false otherwise
isSetVersion() - Method in class org.apache.hadoop.hive.metastore.api.Version
Returns true if field version is set (has been asigned a value) and false otherwise
isSetViewExpandedText() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field viewExpandedText is set (has been asigned a value) and false otherwise
isSetViewOriginalText() - Method in class org.apache.hadoop.hive.metastore.api.Table
Returns true if field viewOriginalText is set (has been asigned a value) and false otherwise
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
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
isStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
isSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
isTblDataDone() - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
isTempPath(FileStatus) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Detect if the supplied file is a temporary path.
isThriftClient - Static variable in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
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
 
isVerbose - Variable in class org.apache.hadoop.hive.ql.session.SessionState
verbose mode
isView() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
isWindowsScript(File) - Static method in class org.apache.hadoop.hive.ql.util.DosToUnix
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.HiveResultSetMetaData
 
isWrapperFor(Class<?>) - Method in class org.apache.hadoop.hive.jdbc.HiveStatement
 
isWritable(int) - Method in class org.apache.hadoop.hive.jdbc.HiveResultSetMetaData
 
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.GenericUDAFCollectSet.GenericUDAFMkSetEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Iterate through original data.
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
iterate(GenericUDAFEvaluator.AggregationBuffer, Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.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(LongWritable, List<DoubleWritable>) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
iterate(LongWritable, Double) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
Note that percentile can be null in a global aggregation with 0 input rows: "select percentile(col, 0.5) from t where false" In that case, iterate(null, null) will be called once.
iterate(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxDoubleEvaluator
 
iterate(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxFloatEvaluator
 
iterate(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxIntEvaluator
 
iterate(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxLongEvaluator
 
iterate(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxShortEvaluator
 
iterate(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxStringEvaluator
 
iterate(Object) - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 

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
 
JavaTestObjFlatFileInputFormat - Class in org.apache.hadoop.hive.ql.io
Simple test object.
JavaTestObjFlatFileInputFormat(String, int) - Constructor for class org.apache.hadoop.hive.ql.io.JavaTestObjFlatFileInputFormat
 
JavaTestObjFlatFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.JavaTestObjFlatFileInputFormat
 
JavaUtils - Class in org.apache.hadoop.hive.common
Collection of Java class loading/reflection related utilities common across Hive.
JavaVoidObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A JavaVoidObjectInspector inspects a Java Void Object.
javaVoidObjectInspector - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory
 
jc - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
jc - Variable in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
JDBC_IMPL_CLASS_VAL - Static variable in class org.apache.hadoop.hive.ql.stats.StatsSetupConst
The value of the user variable "hive.stats.dbclass" to use JDBC implementation.
JdbcColumn - Class in org.apache.hadoop.hive.jdbc
Column metadata.
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.
JdbcSessionState() - Constructor for class org.apache.hadoop.hive.jdbc.JdbcSessionState
 
JdbcSessionState(HiveConf) - Constructor for class org.apache.hadoop.hive.jdbc.JdbcSessionState
 
JDBCStatsAggregator - Class in org.apache.hadoop.hive.ql.stats.jdbc
 
JDBCStatsAggregator() - Constructor for class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsAggregator
 
JDBCStatsPublisher - Class in org.apache.hadoop.hive.ql.stats.jdbc
 
JDBCStatsPublisher() - Constructor for class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
JDBCStatsSetupConstants - Class in org.apache.hadoop.hive.ql.stats.jdbc
 
JDBCStatsSetupConstants() - Constructor for class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
JdbcTable - Class in org.apache.hadoop.hive.jdbc
Table metadata.
JdbcTable(String, String, String, String) - Constructor for class org.apache.hadoop.hive.jdbc.JdbcTable
 
JDOConnectionURLHook - Interface in org.apache.hadoop.hive.metastore.hooks
JDOConnectURLHook is used to get the URL that JDO uses to connect to the database that stores the metastore data.
JettyShims - Interface in org.apache.hadoop.hive.shims
Since Hadoop ships with different versions of Jetty in different versions, Hive uses a shim layer to access the parts of the API that have changed.
JettyShims.Server - Interface in org.apache.hadoop.hive.shims
Server.
jj_nt - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
Next token.
jjFillToken() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
 
jjstrLiteralImages - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Token literal values.
jjtAddChild(Node, int) - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This method tells the node to add its argument to the node's list of children.
jjtAddChild(Node, int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
JJTASYNC - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtClose() - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This method is called after all the child nodes have been added.
jjtClose() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
JJTCOMMAORSEMICOLON - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTLISTCONTENTS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTMAP - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTMAPCONTENTS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTCONSTVALUE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTDEFINITION - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTDEFINITIONTYPE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTENUM - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTENUMDEF - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTENUMDEFLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTEXTENDS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELD - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELDLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELDREQUIREDNESS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELDTYPE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFIELDVALUE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFLAGARGS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFUNCTION - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTFUNCTIONTYPE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtGetChild(int) - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This method returns a child node.
jjtGetChild(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
jjtGetNumChildren() - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
Return the number of children the node has.
jjtGetNumChildren() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
jjtGetParent() - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
 
jjtGetParent() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
JJTHEADER - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTHEADERLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTINCLUDE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTNAMESPACE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtNodeName - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtOpen() - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This method is called after the node has been made the current node.
jjtOpen() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
jjtree - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
JJTSENUM - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTSENUMDEF - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTSENUMDEFLIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTSERVICE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
jjtSetParent(Node) - Method in interface org.apache.hadoop.hive.serde2.dynamic_type.Node
This pair of methods are used to inform the node of its parent.
jjtSetParent(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleNode
 
JJTSTART - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTSTRUCT - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTthrift_grammarState - Class in org.apache.hadoop.hive.serde2.dynamic_type
 
JJTthrift_grammarState() - Constructor for class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
JJTTHROWS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEBOOL - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEBYTE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEDEF - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEDEFINITION - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEDOUBLE - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEI16 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEI32 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEI64 - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPELIST - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPEMAP - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPESET - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTTYPESTRING - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTUNFLAGARGS - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
JJTXCEPTION - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTreeConstants
 
job - Variable in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
jobClose(Configuration, boolean, JobCloseFeedBack) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
jobClose(Configuration, boolean, JobCloseFeedBack) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
jobClose(Configuration, boolean, JobCloseFeedBack) - 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.
JobCloseFeedBack - Class in org.apache.hadoop.hive.ql.exec
After this job closed, some data (feedbacks) can be passed to descendant jobs.
JobCloseFeedBack() - Constructor for class org.apache.hadoop.hive.ql.exec.JobCloseFeedBack
 
JobCloseFeedBack.FeedBackType - Enum in org.apache.hadoop.hive.ql.exec
 
jobConf - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
jobId - Variable in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
JobTrackerState - Enum in org.apache.hadoop.hive.service
 
JobTrackerURLResolver - Class in org.apache.hadoop.hive.ql.exec
JobTrackerURLResolver.
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(boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.JoinCond
Constructor for a UNIQUEJOIN cond.
JoinCondDesc - Class in org.apache.hadoop.hive.ql.plan
Join conditions Descriptor implementation.
JoinCondDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
JoinCondDesc(int, int, int) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
JoinCondDesc(JoinCond) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
JoinDesc - Class in org.apache.hadoop.hive.ql.plan
Join operator Descriptor implementation.
JoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>, boolean, JoinCondDesc[], Map<Byte, List<ExprNodeDesc>>) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>, boolean, JoinCondDesc[]) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(Map<Byte, List<ExprNodeDesc>>, List<String>, JoinCondDesc[]) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
JoinDesc(JoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.JoinDesc
 
joinFilterObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The ObjectInspectors for join filters.
joinFilterObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
The ObjectInspectors for join filters.
joinFilters - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The filters for join
joinFilters - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
The filters for join
joinKeys - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
The expressions for join inputs's join keys.
joinKeys - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
The expressions for join inputs's join keys.
joinKeysObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
The ObjectInspectors for the join inputs's join keys.
joinKeysObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
The ObjectInspectors for the join inputs's join keys.
joinKeysStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
The standard ObjectInspectors for the join inputs's join keys.
joinKeysStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
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
 
JoinOperator.SkewkeyTableCounter - Enum in org.apache.hadoop.hive.ql.exec
SkewkeyTableCounter.
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
 
joinPlan(Operator<? extends Serializable>, Task<? extends Serializable>, Task<? extends Serializable>, GenMRProcContext, int, boolean, 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.
JoinReorder - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of rule-based join table reordering optimization.
JoinReorder() - Constructor for class org.apache.hadoop.hive.ql.optimizer.JoinReorder
 
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
JoinType.
JoinUtil - Class in org.apache.hadoop.hive.ql.exec
 
JoinUtil() - Constructor for class org.apache.hadoop.hive.ql.exec.JoinUtil
 
joinValues - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The expressions for join inputs.
joinValues - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
The expressions for join outputs.
joinValuesObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The ObjectInspectors for the join inputs.
joinValuesObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
The ObjectInspectors for the join inputs.
joinValuesStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The standard ObjectInspectors for the join inputs.
joinValuesStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
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
 
keyName - Variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
keyObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
keysCurrentGroup - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
keySet() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
keyValueProperty() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KeyWrapper - Class in org.apache.hadoop.hive.ql.exec
 
KeyWrapper() - Constructor for class org.apache.hadoop.hive.ql.exec.KeyWrapper
 
KeyWrapperFactory - Class in org.apache.hadoop.hive.ql.exec
 
KeyWrapperFactory(ExprNodeEvaluator[], ObjectInspector[], ObjectInspector[]) - Constructor for class org.apache.hadoop.hive.ql.exec.KeyWrapperFactory
 
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_AFTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_AFTER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_CHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_CHANGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_COLUMN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COLUMN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_COMPUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_COMPUTE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_DATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_DBPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DBPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_DEFERRED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DEFERRED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_EXCLUSIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_EXCLUSIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_FIRST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FIRST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_FORMATTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_FORMATTED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_IDXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_IDXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_INDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_INPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_INPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_LATERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LATERAL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_LOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_LOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_OUTPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_OUTPUTDRIVER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_PRESERVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_PRESERVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_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_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_REPAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_REPAIR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_SEMI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SEMI - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_SHARED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SHARED - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SHOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SHOW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_STATISTICS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_STATISTICS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TBLPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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_UPDATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_UPDATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_USE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
KW_USE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
KW_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
 
kwRole() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
kwUser() - Method 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.ExecMapperContext
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.ExecReducer
 
l4j - Static variable in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
l4j - Static variable in class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexInputFormat
 
l4j - Static variable in class org.apache.hadoop.hive.ql.index.compact.HiveCompactIndexResult
 
l4j - Static variable in class org.apache.hadoop.hive.ql.index.HiveIndex
 
LA(int) - Method in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.ANTLRNoCaseStringStream
 
LA(int) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver.ANTLRNoCaseStringStream
 
last() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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
 
lastSeenSyncPos() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns the last seen sync position.
lateralView() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LateralViewForwardDesc - Class in org.apache.hadoop.hive.ql.plan
LateralViewForwardDesc.
LateralViewForwardDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LateralViewForwardDesc
 
LateralViewForwardOperator - Class in org.apache.hadoop.hive.ql.exec
LateralViewForwardOperator.
LateralViewForwardOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
LateralViewJoinDesc - Class in org.apache.hadoop.hive.ql.plan
LateralViewJoinDesc.
LateralViewJoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
LateralViewJoinDesc(ArrayList<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
LateralViewJoinOperator - Class in org.apache.hadoop.hive.ql.exec
The lateral view join operator is used for FROM src LATERAL VIEW udtf()...
LateralViewJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
 
launchTask(Task<? extends Serializable>, String, boolean, Map<TaskResult, TaskRunner>, String, int, DriverContext) - Method in class org.apache.hadoop.hive.ql.Driver
Launches a new task
LAZY_BOOLEAN_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_BYTE_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_DOUBLE_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_FLOAT_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_INT_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_LONG_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_SHORT_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
LAZY_VOID_OBJECT_INSPECTOR - Static variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.LazyPrimitiveObjectInspectorFactory
 
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.
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.
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.
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.
LazyBinaryUtils.RecordInfo - Class in org.apache.hadoop.hive.serde2.lazybinary
Record is the unit that data is serialized in.
LazyBinaryUtils.RecordInfo() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.RecordInfo
 
LazyBinaryUtils.VInt - Class in org.apache.hadoop.hive.serde2.lazybinary
A zero-compressed encoded integer.
LazyBinaryUtils.VInt() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VInt
 
LazyBinaryUtils.VLong - Class in org.apache.hadoop.hive.serde2.lazybinary
A zero-compressed encoded long.
LazyBinaryUtils.VLong() - Constructor for class org.apache.hadoop.hive.serde2.lazybinary.LazyBinaryUtils.VLong
 
LazyBinaryVoid - Class in org.apache.hadoop.hive.serde2.lazybinary
LazyBinaryVoid for NULL which is a placeholder class and it does not need to store any data.
LazyBoolean - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of boolean.
LazyBoolean(LazyBooleanObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyBoolean
 
LazyBoolean(LazyBoolean) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyBoolean
 
LazyBooleanObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableBooleanObjectInspector inspects a BooleanWritable Object.
LazyByte - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Byte.
LazyByte(LazyByteObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyByte
 
LazyByte(LazyByte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyByte
 
LazyByteObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableByteObjectInspector inspects a ByteWritable Object.
LazyDecompressionCallback - Interface in org.apache.hadoop.hive.serde2.columnar
Used to call back lazy decompression process.
LazyDouble - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Double.
LazyDouble(LazyDoubleObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyDouble
 
LazyDouble(LazyDouble) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyDouble
 
LazyDoubleObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableDoubleObjectInspector inspects a DoubleWritable Object.
LazyFactory - Class in org.apache.hadoop.hive.serde2.lazy
LazyFactory.
LazyFloat - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Double.
LazyFloat(LazyFloatObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyFloat
 
LazyFloat(LazyFloat) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyFloat
 
LazyFloatObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A FloatObjectInspector inspects a FloatWritable Object.
LazyInteger - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Integer.
LazyInteger(LazyIntObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyInteger
 
LazyInteger(LazyInteger) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyInteger
 
LazyIntObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableIntObjectInspector inspects a IntWritable Object.
LazyListObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
LazyListObjectInspector works on array data that is stored in LazyArray.
LazyListObjectInspector(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.
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.
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.
LazyShort - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a value of Short.
LazyShort(LazyShortObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyShort
 
LazyShort(LazyShort) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyShort
 
LazyShortObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
A WritableShortObjectInspector inspects a ShortWritable Object.
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
SerDeParameters.
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.
LazyUnion - Class in org.apache.hadoop.hive.serde2.lazy
LazyObject for storing a union.
LazyUnion(LazyUnionObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.lazy.LazyUnion
Construct a LazyUnion object with the ObjectInspector.
LazyUnionObjectInspector - Class in org.apache.hadoop.hive.serde2.lazy.objectinspector
LazyUnionObjectInspector works on union data that is stored in LazyUnion.
LazyUnionObjectInspector(List<ObjectInspector>, byte, Text, boolean, byte) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
LazyUnionObjectInspector(List<ObjectInspector>, byte, Text) - Constructor for class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
LazyUtils - Class in org.apache.hadoop.hive.serde2.lazy
LazyUtils.
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
 
LEFT_SEMI_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.
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.ql.metadata.MetaDataFormatUtils
 
LINE_DELIM - Static variable in class org.apache.hadoop.hive.serde.Constants
 
LINE_SEP - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveUtils
 
LineageCtx - Class in org.apache.hadoop.hive.ql.optimizer.lineage
This class contains the lineage context that is passed while walking the operator tree in Lineage.
LineageCtx(ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx
Constructor.
LineageCtx.Index - Class in org.apache.hadoop.hive.ql.optimizer.lineage
 
LineageCtx.Index() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
Constructor.
LineageInfo - Class in org.apache.hadoop.hive.ql.hooks
This class contains the lineage information that is passed to the PreExecution hook.
LineageInfo() - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo
Constructor.
LineageInfo - Class in org.apache.hadoop.hive.ql.tools
This class prints out the lineage info.
LineageInfo() - Constructor for class org.apache.hadoop.hive.ql.tools.LineageInfo
 
LineageInfo.BaseColumnInfo - Class in org.apache.hadoop.hive.ql.hooks
Base Column information.
LineageInfo.BaseColumnInfo() - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
LineageInfo.DataContainer - Class in org.apache.hadoop.hive.ql.hooks
Table or Partition data container.
LineageInfo.DataContainer(Table) - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
Constructor for non partitioned tables.
LineageInfo.DataContainer(Table, Partition) - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.DataContainer
Constructor for a partitioned tables partition.
LineageInfo.Dependency - Class in org.apache.hadoop.hive.ql.hooks
This class tracks the dependency information for the base column.
LineageInfo.Dependency() - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
LineageInfo.DependencyKey - Class in org.apache.hadoop.hive.ql.hooks
Class that captures the lookup key for the dependency.
LineageInfo.DependencyKey(LineageInfo.DataContainer, FieldSchema) - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.DependencyKey
Constructor.
LineageInfo.DependencyType - Enum in org.apache.hadoop.hive.ql.hooks
Enum to track dependency.
LineageInfo.TableAliasInfo - Class in org.apache.hadoop.hive.ql.hooks
 
LineageInfo.TableAliasInfo() - Constructor for class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
LineageState - Class in org.apache.hadoop.hive.ql.session
LineageState.
LineageState() - Constructor for class org.apache.hadoop.hive.ql.session.LineageState
Constructor.
linfo - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Lineage information for the query.
linfo - Variable in class org.apache.hadoop.hive.ql.QueryPlan
Lineage information for the query.
LINT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
LINTSTRING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 
list_column_privileges(String, PrincipalType, String, String, List<String>, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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_db_privileges(String, PrincipalType, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
list_global_privileges(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
list_partition_privileges(String, PrincipalType, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
list_privileges(String, PrincipalType, HiveObjectRef, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_privileges_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
list_privileges(String, PrincipalType, HiveObjectRef, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_privileges_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
list_privileges(String, PrincipalType, HiveObjectRef) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
list_resource(SessionState.ResourceType, List<String>) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
list_roles(String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_roles_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
list_roles(String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_roles_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
list_roles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
list_roles(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
list_roles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
list_roles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
list_roles(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
list_table_privileges(String, PrincipalType, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
LIST_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
listAllTableGrants(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listAllTableGrants(String, PrincipalType, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listAllTableGrants(String, PrincipalType, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listIndexes(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
list all the index names of the give base table.
listIndexes(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
list indexes of the give base table
listIndexNames(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
list indexes of the give base table
listIndexNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
list all the index names of the give base table.
listIndexNames(String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listIndexNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
ListObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
ListObjectInspector.
ListObjectsEqualComparer - Class in org.apache.hadoop.hive.serde2.objectinspector
Compare two list of objects.
ListObjectsEqualComparer(ObjectInspector[], ObjectInspector[]) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ListObjectsEqualComparer
 
listPartitionAllColumnGrants(String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionNames(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionNames(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionNames(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionNames(String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionNames(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPartitionNamesByFilter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPartitionNamesByFilter(String, String, String, short) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPartitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitions(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitions(String, String, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitions(String, String, List<String>, short) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionsByFilter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Get list of partitions matching specified filter
listPartitionsWithAuthInfo(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionsWithAuthInfo(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listPartitionsWithAuthInfo(String, String, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPartitionsWithAuthInfo(String, String, List<String>, short, String, List<String>) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
listPrincipalDBGrants(String, PrincipalType, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalDBGrants(String, PrincipalType, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalGlobalGrants(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalGlobalGrants(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalPartitionColumnGrants(String, PrincipalType, String, String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalPartitionColumnGrants(String, PrincipalType, String, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalPartitionGrants(String, PrincipalType, String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalPartitionGrants(String, PrincipalType, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listPrincipalTableColumnGrants(String, PrincipalType, String, String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listPrincipalTableColumnGrants(String, PrincipalType, String, String, String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listRoleNames() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
listRoleNames() - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
list all role names
listRoleNames() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listRoleNames() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listRoles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listRoles(String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
listRoles(String, PrincipalType) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
listStatus(JobConf, Path) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
listStatusRecursively(FileSystem, FileStatus, List<FileStatus>) - Static method in class org.apache.hadoop.hive.common.FileUtils
Recursively lists status for all files starting from a particular directory (or individual file as base case).
listTableAllColumnGrants(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listTableAllPartitionColumnGrants(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
listTableAllPartitionGrants(String, String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
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.
LoadDesc - Class in org.apache.hadoop.hive.ql.plan
LoadDesc.
LoadDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LoadDesc
 
LoadDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadDesc
 
loadDynamicPartitions(Path, String, Map<String, String>, boolean, int, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Given a source directory name of the load path, load all dynamically generated partitions into the specified table and return a list of strings that represent the dynamic partition paths.
LoadFileDesc - Class in org.apache.hadoop.hive.ql.plan
LoadFileDesc.
LoadFileDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
LoadFileDesc(String, String, boolean, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
LoadMultiFilesDesc - Class in org.apache.hadoop.hive.ql.plan
LoadMultiFilesDesc.
LoadMultiFilesDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
LoadMultiFilesDesc(List<String>, List<String>, boolean, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
loadPartition(Path, String, Map<String, String>, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Load a directory into a Hive Table Partition - Alters existing content of the partition with the contents of loadPath.
LoadSemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
LoadSemanticAnalyzer.
LoadSemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
loadStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
loadTable(Path, String, boolean, boolean) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Load a directory into a Hive Table.
LoadTableDesc - Class in org.apache.hadoop.hive.ql.plan
LoadTableDesc.
LoadTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
LoadTableDesc(String, String, TableDesc, Map<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
LoadTableDesc(String, String, TableDesc, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
LoadTableDesc(String, String, TableDesc, DynamicPartitionCtx) - Constructor for class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
LOCAL_MAPJOIN - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
localizeKeys(Map<String, Object>) - Method in class org.apache.hadoop.hive.ql.Context
Given a mapping from paths to objects, localize any MR tmp paths
localizeMRTmpFiles(Context) - Method in class org.apache.hadoop.hive.ql.exec.Task
Localize a task tree
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.CopyTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.FetchTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.FunctionTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.MoveTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.exec.Task
If this task uses any map-reduce intermediate data (either for reading or for writing), localize them (using the supplied Context).
localizeMRTmpFilesImpl(Context) - Method in class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeTask
 
localizeMRTmpFileURI(String) - Method in class org.apache.hadoop.hive.ql.Context
Given a URI for mapreduce intermediate output, swizzle the it to point to the local file system.
localizePaths(List<String>) - Method in class org.apache.hadoop.hive.ql.Context
Given a list of paths, localize any MR tmp paths contained therein
LocalMapJoinProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.physical
Node processor factory for skew join resolver.
LocalMapJoinProcFactory.LocalMapJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
LocalMapJoinProcessor.
LocalMapJoinProcFactory.LocalMapJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.LocalMapJoinProcessor
 
LocalMapJoinProcFactory.MapJoinFollowByProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
MapJoinFollowByProcessor.
LocalMapJoinProcFactory.MapJoinFollowByProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.MapJoinFollowByProcessor
 
locatorsUpdateCopy() - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
lock(HiveLockObject, HiveLockMode, boolean, int, int) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
lock(List<HiveLockObj>, boolean, int, int) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
lock(List<HiveLockObj>, boolean, int, int) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
lock(HiveLockObject, HiveLockMode, boolean, int, int) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
LOCK - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
LockException - Exception in org.apache.hadoop.hive.ql.lockmgr
Exception from lock manager.
LockException() - Constructor for exception org.apache.hadoop.hive.ql.lockmgr.LockException
 
LockException(String) - Constructor for exception org.apache.hadoop.hive.ql.lockmgr.LockException
 
LockException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.lockmgr.LockException
 
LockException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.lockmgr.LockException
 
lockMode() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
lockStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
LockTableDesc - Class in org.apache.hadoop.hive.ql.plan
LockTableDesc.
LockTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
LockTableDesc(String, String, Map<String, String>, String) - Constructor for class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
LOG - Static variable in class org.apache.hadoop.hive.jdbc.HiveQueryResultSet
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStore
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.HiveMetaStoreFsImpl
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
LOG - Static variable in class org.apache.hadoop.hive.metastore.Warehouse
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.AutoProgressor
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
LOG - Static variable in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
LOG - Variable in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat
 
LOG - Static variable in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
LOG - Static variable in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
LOG - Static variable in class org.apache.hadoop.hive.ql.metadata.HiveMetaStoreChecker
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.DefaultLineage
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.ReduceSinkLineage
 
LOG - Static variable in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.UnionLineage
 
LOG - 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.plan.PlanUtils
 
LOG - Static variable in class org.apache.hadoop.hive.ql.ppd.ExprWalkerInfo
 
LOG - Static variable in class org.apache.hadoop.hive.ql.ppd.OpProcFactory
 
LOG - Static variable in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
LOG - Static variable in class org.apache.hadoop.hive.ql.processors.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.DelimitedJSONSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazy.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.lazy.objectinspector.LazyUnionObjectInspector
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
LOG - Static variable in class org.apache.hadoop.hive.serde2.TestSerDe
 
LOG - Static variable in class org.apache.hadoop.hive.service.HiveServer.HiveServerHandler
 
LOG - Static variable in interface org.apache.hadoop.hive.shims.HadoopShims
 
logExpr(Node, ExprWalkerInfo) - Method in class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
 
logPlanProgress(QueryPlan) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
 
logStats() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
logVars(PrintStream) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
loi - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
loi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
loi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
LongObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A LongObjectInspector inspects an Object representing a Long.
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
 
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.Complex
 

M

main(String[]) - Static method in class org.apache.hadoop.hive.cli.CliDriver
 
main(String[]) - Static method in class org.apache.hadoop.hive.cli.RCFileCat
 
main(String[]) - Static method in class org.apache.hadoop.hive.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.io.PerformTestRCFileAndSeqFile
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.io.TestFlatFileInputFormat
 
main(String[]) - Static method in class org.apache.hadoop.hive.ql.io.TestRCFile
For debugging and testing.
main(String[]) - Static method in class org.apache.hadoop.hive.ql.tools.LineageInfo
 
main(String[]) - Static method in class org.apache.hadoop.hive.scripts.extracturl
 
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
 
makeChild(Task<?>, Task<? extends Serializable>...) - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
makeDir(Path, HiveConf) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
makeDynamicPartName(Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Given a dynamic partition specification, return the path corresponding to the static part of partition specification.
makeFilterStringFromMap(Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Given a map of partition column names to values, this creates a filter string that can be used to call the *byFilter methods
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(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
makePartName(Map<String, String>, boolean) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Makes a partition name from a specification
makePartName(List<FieldSchema>, List<String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
 
makePartPath(Map<String, String>) - Static method in class org.apache.hadoop.hive.metastore.Warehouse
Given a partition specification, return the path corresponding to the partition spec.
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
 
makeSpecFromName(Map<String, String>, Path) - 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
 
MapAggrMemErrorHeuristic - Class in org.apache.hadoop.hive.ql.exec.errors
Detects out-of-memory errors when hash tables in map-based aggregation group by queries take up too much memory.
MapAggrMemErrorHeuristic() - Constructor for class org.apache.hadoop.hive.ql.exec.errors.MapAggrMemErrorHeuristic
 
mapDirToFop(String, FileSinkOperator) - Method in class org.apache.hadoop.hive.ql.session.LineageState
Adds a mapping from the load work to the file sink operator.
mapDone() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
mapDone() - Method in class org.apache.hadoop.hive.ql.exec.MapRedTask
 
mapInputToDP(List<ColumnInfo>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
MapJoinCounterHook - Class in org.apache.hadoop.hive.ql.hooks
 
MapJoinCounterHook() - Constructor for class org.apache.hadoop.hive.ql.hooks.MapJoinCounterHook
 
MapJoinDesc - Class in org.apache.hadoop.hive.ql.plan
Map Join operator Descriptor implementation.
MapJoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
MapJoinDesc(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
MapJoinDesc(Map<Byte, List<ExprNodeDesc>>, TableDesc, Map<Byte, List<ExprNodeDesc>>, List<TableDesc>, List<TableDesc>, List<String>, int, JoinCondDesc[], Map<Byte, List<ExprNodeDesc>>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
MapJoinDoubleKeys - Class in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinDoubleKeys() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
MapJoinDoubleKeys(Object, Object) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
MapJoinFactory - Class in org.apache.hadoop.hive.ql.optimizer
Operator factory for MapJoin processing.
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
 
MapJoinMetaData - Class in org.apache.hadoop.hive.ql.exec
 
MapJoinMetaData() - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinMetaData
 
MapJoinObjectKey - Class in org.apache.hadoop.hive.ql.exec.persistence
Map Join Object used for both key.
MapJoinObjectKey() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
MapJoinObjectKey(Object[]) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
MapJoinObjectValue - Class in org.apache.hadoop.hive.ql.exec.persistence
Map Join Object used for both key and value.
MapJoinObjectValue() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
MapJoinObjectValue(int, MapJoinRowContainer<Object[]>) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.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(AbstractMapJoinOperator<? extends MapJoinDesc>) - Constructor for class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
MapJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer
Implementation of one of the rule-based map join optimization.
MapJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor
empty constructor.
MapJoinProcessor.CurrentMapJoin - Class in org.apache.hadoop.hive.ql.optimizer
CurrentMapJoin.
MapJoinProcessor.CurrentMapJoin() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.CurrentMapJoin
 
MapJoinProcessor.Default - Class in org.apache.hadoop.hive.ql.optimizer
Default.
MapJoinProcessor.Default() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.Default
 
MapJoinProcessor.MapJoinDefault - Class in org.apache.hadoop.hive.ql.optimizer
MapJoinDefault.
MapJoinProcessor.MapJoinDefault() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinDefault
 
MapJoinProcessor.MapJoinFS - Class in org.apache.hadoop.hive.ql.optimizer
MapJoinFS.
MapJoinProcessor.MapJoinFS() - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinFS
 
MapJoinProcessor.MapJoinWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer
MapJoinWalkerCtx.
MapJoinProcessor.MapJoinWalkerCtx(List<AbstractMapJoinOperator<? extends MapJoinDesc>>, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
MapJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
An implementation of PhysicalPlanResolver.
MapJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver
 
MapJoinResolver.LocalMapJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.physical
A container of current task and parse context.
MapJoinResolver.LocalMapJoinProcCtx(Task<? extends Serializable>, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
MapJoinRowContainer<Row> - Class in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinRowContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
MapJoinSingleKey - Class in org.apache.hadoop.hive.ql.exec.persistence
 
MapJoinSingleKey() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
MapJoinSingleKey(Object) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
mapJoinTables - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
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
MapObjectInspector.
MapOperator - Class in org.apache.hadoop.hive.ql.exec
Map operator.
MapOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.MapOperator
 
MapOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
Counter.
mapPattern - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
mapProgress - Variable in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
MapredLocalTask - Class in org.apache.hadoop.hive.ql.exec
 
MapredLocalTask() - Constructor for class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
MapredLocalTask(MapredLocalWork, JobConf, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
MapredLocalWork - Class in org.apache.hadoop.hive.ql.plan
MapredLocalWork.
MapredLocalWork() - Constructor for class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
MapredLocalWork(LinkedHashMap<String, Operator<? extends Serializable>>, LinkedHashMap<String, FetchWork>) - Constructor for class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
MapredLocalWork(MapredLocalWork) - Constructor for class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
MapredLocalWork.BucketMapJoinContext - Class in org.apache.hadoop.hive.ql.plan
 
MapredLocalWork.BucketMapJoinContext() - Constructor for class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
MapRedTask - Class in org.apache.hadoop.hive.ql.exec
Extension of ExecDriver: - can optionally spawn a map-reduce task from a separate jvm - will make last minute adjustments to map-reduce job parameters, viz: * estimating number of reducers * estimating whether job should run locally
MapRedTask() - Constructor for class org.apache.hadoop.hive.ql.exec.MapRedTask
 
MapRedTask(MapredWork, JobConf, boolean) - Constructor for class org.apache.hadoop.hive.ql.exec.MapRedTask
 
MapredWork - Class in org.apache.hadoop.hive.ql.plan
MapredWork.
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, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.MapredWork
 
mapSeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
mapStarted() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
mapStarted() - Method in class org.apache.hadoop.hive.ql.exec.MapRedTask
 
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.
mark(int) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
markSupported() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
matchCost(TypeInfo, TypeInfo, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
Returns -1 if passed does not match accepted.
matchFilesOrDir(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer
 
MAX_SUBST - Static variable in class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
maxNextCharInd - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
maxPartitions - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.model.MDatabase
To create a database object
MDBPrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MDBPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
MDBPrivilege(String, String, MDatabase, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
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
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.ExecMapper
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
memoryMXBean - Static variable in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
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.GenericUDAFCollectSet.GenericUDAFMkSetEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Merge with partial aggregation result.
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
merge(GenericUDAFEvaluator.AggregationBuffer, Object) - Method in class org.apache.hadoop.hive.ql.udf.generic.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(List<Text>) - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Takes a serialized n-gram estimator object created by the serialize() method and merges it with the current n-gram object.
merge(List<DoubleWritable>) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Takes a serialized histogram created by the serialize() method and merges it with the current histogram object.
merge(UDAFPercentile.State) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
merge(UDAFPercentile.State) - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
merge(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxDoubleEvaluator
 
merge(FloatWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxFloatEvaluator
 
merge(IntWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxIntEvaluator
 
merge(LongWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxLongEvaluator
 
merge(ShortWritable) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxShortEvaluator
 
merge(Text) - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxStringEvaluator
 
merge() - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
mergeDependency(Operator<? extends Serializable>, ColumnInfo, LineageInfo.Dependency) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
Merges the new dependencies in dep to the existing dependencies of (op, ci).
mergeMapJoinUnion(UnionOperator, GenMRProcContext, int) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
 
mergeRHSSemijoin(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
Merge the rhs tables from another join tree.
mergeUniqElems(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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.
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
 
META_TABLE_STORAGE - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
MetaDataFormatUtils - Class in org.apache.hadoop.hive.ql.metadata
This class provides methods to format table and index information.
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 exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
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.HiveObjectPrivilege
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Index
 
metaDataMap - Static variable in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
metaDataMap - Static variable in 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.PrincipalPrivilegeSet
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.Role
 
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_index_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_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_index_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_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_all_databases_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.ThriftHiveMetastore.grant_privileges_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.metastore.api.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.ql.plan.api.Adjacency
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Graph
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Operator
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Query
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Stage
 
metaDataMap - Static variable in class org.apache.hadoop.hive.ql.plan.api.Task
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde.test.InnerStruct
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
metaDataMap - Static variable in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
metaDataMap - Static variable in class org.apache.hadoop.hive.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.getQueryPlan_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
metaDataMap - Static variable in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
metadataTag - Static variable in class org.apache.hadoop.hive.ql.exec.persistence.AbstractMapJoinKey
 
metadataTag - Variable in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
MetadataTypedColumnsetSerDe - Class in org.apache.hadoop.hive.serde2
MetadataTypedColumnsetSerDe.
MetadataTypedColumnsetSerDe() - Constructor for class org.apache.hadoop.hive.serde2.MetadataTypedColumnsetSerDe
 
MetaException - Exception in org.apache.hadoop.hive.metastore.api
 
MetaException() - Constructor for exception org.apache.hadoop.hive.metastore.api.MetaException
 
MetaException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.MetaException
 
MetaException(MetaException) - Constructor for exception org.apache.hadoop.hive.metastore.api.MetaException
Performs a deep copy on other.
MetaException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
metastoreCheck() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
MetaStoreFS - Interface in org.apache.hadoop.hive.metastore
Define a set of APIs that may vary in different environments
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.
Metrics - Class in org.apache.hadoop.hive.common.metrics
Metrics Subsystem - allows exposure of a number of named parameters/counters via jmx, intended to be used as a static subsystem Has a couple of primary ways it can be used: (i) Using the set and get methods to set and get named parameters (ii) Using the incrementCounter method to increment and set named parameters in one go, rather than having to make a get and then a set.
Metrics() - Constructor for class org.apache.hadoop.hive.common.metrics.Metrics
 
Metrics.MetricsScope - Class in org.apache.hadoop.hive.common.metrics
MetricsScope : A class that encapsulates an idea of a metered scope.
MetricsMBean - Interface in org.apache.hadoop.hive.common.metrics
MBean definition for metrics tracking from jmx
MetricsMBeanImpl - Class in org.apache.hadoop.hive.common.metrics
 
MetricsMBeanImpl() - Constructor for class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
mExponent() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MFieldSchema - Class in org.apache.hadoop.hive.metastore.model
Represent a column or a type of a table or object
MFieldSchema() - Constructor for class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
MFieldSchema(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
MGlobalPrivilege - Class in org.apache.hadoop.hive.metastore.model
User global level privileges
MGlobalPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
MGlobalPrivilege(String, String, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
mGREATERTHAN() - Method in class org.apache.hadoop.hive.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
 
MIndex - Class in org.apache.hadoop.hive.metastore.model
Represents hive's index definition.
MIndex() - Constructor for class org.apache.hadoop.hive.metastore.model.MIndex
 
MIndex(String, MTable, int, int, Map<String, String>, MTable, MStorageDescriptor, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MIndex
 
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_AFTER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ALL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ALTER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ANALYZE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_AND() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ARCHIVE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ARRAY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_AS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ASC() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_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_CHANGE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CLUSTER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CLUSTERED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_CLUSTERSTATUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COLLECTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COLUMN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COLUMNS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COMMENT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_COMPUTE() - 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_DATABASES() - 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_DBPROPERTIES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DEFERRED() - 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_DISABLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DISTINCT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DISTRIBUTE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DOUBLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_DROP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ELEM_TYPE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ELSE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ENABLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_END() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ESCAPED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXCLUSIVE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXISTS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_EXPLAIN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_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_FILEFORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FIRST() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FLOAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FORMATTED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FROM() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FULL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FUNCTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_FUNCTIONS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_GRANT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_GROUP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_HAVING() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_HOLD_DDLTIME() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_IDXPROPERTIES() - 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_INDEX() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INDEXES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INPATH() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INPUTDRIVER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INPUTFORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INSERT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_INTERSECT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_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_LATERAL() - 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_LOCKS() - 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_NO_DROP() - 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_OFFLINE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ON() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OPTION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_ORDER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OUT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OUTER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OUTPUTDRIVER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_OUTPUTFORMAT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_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_PRESERVE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_PROCEDURE() - 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_READONLY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_READS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REBUILD() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RECORDREADER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RECORDWRITER() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REDUCE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REGEXP() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_RENAME() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REPAIR() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_REPLACE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_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_SEMI() - 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_SHARED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SHOW() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SHOW_DATABASE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SMALLINT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SORT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SORTED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_SSL() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STATISTICS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STORED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STREAMTABLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STRING() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_STRUCT() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TABLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TABLES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TABLESAMPLE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TBLPROPERTIES() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TEMPORARY() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_TERMINATED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_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_TOUCH() - 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_UNARCHIVE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNDO() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNION() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNIONTYPE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNIQUEJOIN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNLOCK() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UNSIGNED() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_UPDATE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mKW_USE() - 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
 
movedParts - Variable in class org.apache.hadoop.hive.ql.plan.MoveWork
List of inserted partitions
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.HiveBaseResultSet
 
moveToHead(T) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MRU
Move an existing item to the head.
moveToInsertRow() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
MoveWork - Class in org.apache.hadoop.hive.ql.plan
MoveWork.
MoveWork() - Constructor for class org.apache.hadoop.hive.ql.plan.MoveWork
 
MoveWork(HashSet<ReadEntity>, HashSet<WriteEntity>) - Constructor for class org.apache.hadoop.hive.ql.plan.MoveWork
 
MoveWork(HashSet<ReadEntity>, HashSet<WriteEntity>, LoadTableDesc, LoadFileDesc, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.MoveWork
 
MPartition - Class in org.apache.hadoop.hive.metastore.model
 
MPartition() - Constructor for class org.apache.hadoop.hive.metastore.model.MPartition
 
MPartition(String, MTable, List<String>, int, int, MStorageDescriptor, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.model.MPartition
 
MPartitionColumnPrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MPartitionColumnPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
MPartitionColumnPrivilege(String, String, MPartition, String, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
MPartitionPrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MPartitionPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
MPartitionPrivilege(String, String, MPartition, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
mPLUS() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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
 
MRole - Class in org.apache.hadoop.hive.metastore.model
 
MRole() - Constructor for class org.apache.hadoop.hive.metastore.model.MRole
 
MRole(String, int, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MRole
 
MRoleMap - Class in org.apache.hadoop.hive.metastore.model
 
MRoleMap() - Constructor for class org.apache.hadoop.hive.metastore.model.MRoleMap
 
MRoleMap(String, String, MRole, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MRoleMap
 
mRPAREN() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
mRSQUARE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MRU<T extends DCLLItem> - Class in org.apache.hadoop.hive.ql.exec.persistence
An MRU (Most Recently Used) cache implementation.
MRU() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.MRU
 
MsckDesc - Class in org.apache.hadoop.hive.ql.plan
MsckDesc.
MsckDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.MsckDesc
For serialization use only.
MsckDesc(String, List<? extends Map<String, String>>, Path, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.MsckDesc
Description of a msck command.
mSEMICOLON() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
MSerDeInfo - Class in org.apache.hadoop.hive.metastore.model
 
MSerDeInfo(String, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
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
 
MTable - Class in org.apache.hadoop.hive.metastore.model
 
MTable() - Constructor for class org.apache.hadoop.hive.metastore.model.MTable
 
MTable(String, MDatabase, MStorageDescriptor, String, int, int, int, List<MFieldSchema>, Map<String, String>, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.model.MTable
 
MTableColumnPrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MTableColumnPrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
MTableColumnPrivilege(String, String, MTable, String, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
MTablePrivilege - Class in org.apache.hadoop.hive.metastore.model
 
MTablePrivilege() - Constructor for class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
MTablePrivilege(String, String, MTable, String, int, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
mTILDE() - Method in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
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
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.ListDelegate
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.MapDelegate
 
mutatesTo(Object, Object) - Method in class org.apache.hadoop.hive.ql.exec.Utilities.SetDelegate
 
mvFileToFinalPath(String, Configuration, boolean, Log, DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.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_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.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.
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.
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 - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeSimpleNode
 
Namespace() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammar
 
nativeSQL(String) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
nbinsOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
newAggregations() - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
newInstance(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
 
newSynchronizedClient(IMetaStoreClient) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Creates a synchronized wrapper for any IMetaStoreClient.
newTable(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
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.HiveQueryResultSet
Moves the cursor down one row from its current position.
next(Writable) - Method in class org.apache.hadoop.hive.ql.exec.BinaryRecordReader
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
next() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
next(Writable) - Method in interface org.apache.hadoop.hive.ql.exec.RecordReader
Returns the number of bytes that we consumed.
next(Writable) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
next(Void, FlatFileInputFormat.RowContainer<R>) - Method in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.FlatFileRecordReader
Returns the next row # and value.
next(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
next(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 - 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
 
NGramEstimator - Class in org.apache.hadoop.hive.ql.udf.generic
A generic, re-usable n-gram estimation class that supports partial aggregations.
NGramEstimator() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Creates a new n-gram estimator object.
NO_TAG - Static variable in class org.apache.hadoop.hive.ql.exec.Task
 
Node - Interface in org.apache.hadoop.hive.ql.lib
This interface defines the functions needed by the walkers and dispatchers.
Node - Interface in org.apache.hadoop.hive.serde2.dynamic_type
 
nodeArity() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
nodeCreated() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
NodeProcessor - Interface in org.apache.hadoop.hive.ql.lib
Base class for processing operators which is no-op.
NodeProcessorCtx - Interface in org.apache.hadoop.hive.ql.lib
Operator Processor Context.
NodeType - Enum in org.apache.hadoop.hive.ql.plan.api
 
noDrop - Variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
NoMatchingMethodException - Exception in org.apache.hadoop.hive.ql.exec
Exception thrown by the UDF and UDAF method resolvers in case no matching method is found.
NoMatchingMethodException(Class<?>, List<TypeInfo>, List<Method>) - Constructor for exception org.apache.hadoop.hive.ql.exec.NoMatchingMethodException
Constructor.
nonDistinctAggrs - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
nonDistinctKeyAggrs - Variable in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
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.exec.HashTableSinkOperator
 
noOuterJoin - Variable in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
noOuterJoin - Variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
normalizeNames(File) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
NoSuchObjectException - Exception in org.apache.hadoop.hive.metastore.api
 
NoSuchObjectException() - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
NoSuchObjectException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
NoSuchObjectException(NoSuchObjectException) - Constructor for exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
Performs a deep copy on other.
NoSuchObjectException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
notifyBadConnectionUrl(String) - Method in interface org.apache.hadoop.hive.metastore.hooks.JDOConnectionURLHook
Alerts this that the connection URL was bad.
NOTSKIPBIGTABLE - Static variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
now() - Static method in class org.apache.hadoop.hive.ql.exec.MapredLocalTask
 
now() - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
NSTR - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
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.
num - Variable in class org.apache.hadoop.hive.ql.io.JavaTestObjFlatFileInputFormat
 
NUM_FILES - Static variable in class org.apache.hadoop.hive.ql.stats.StatsSetupConst
The name of the statistic Row Count to be published or gathered.
NUM_PARTITIONS - Static variable in class org.apache.hadoop.hive.ql.stats.StatsSetupConst
The name of the statistic Row Count to be published or gathered.
numAliases - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
numAliases - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
Number - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
Number - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
numCols - Variable in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
numDistinctExprs - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
numDistributionKeys - Variable in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
numDynParts - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
numDynParts - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
NumericHistogram - Class in org.apache.hadoop.hive.ql.udf.generic
A generic, re-usable histogram class that supports partial aggregations.
NumericHistogram() - Constructor for class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Creates a new histogram object.
NumericOpMethodResolver - Class in org.apache.hadoop.hive.ql.exec
The class implements the method resolution for operators like (+, -, *, %).
NumericOpMethodResolver(Class<? extends UDF>) - Constructor for class org.apache.hadoop.hive.ql.exec.NumericOpMethodResolver
Constuctor.
NumericUDAF - Class in org.apache.hadoop.hive.ql.exec
Base class of numeric UDAFs like sum and avg which need a NumericUDAFEvaluatorResolver.
NumericUDAF() - Constructor for class org.apache.hadoop.hive.ql.exec.NumericUDAF
Constructor.
NumericUDAFEvaluatorResolver - Class in org.apache.hadoop.hive.ql.exec
Resolver for Numeric UDAFs like sum and avg.
NumericUDAFEvaluatorResolver(Class<? extends UDAF>) - Constructor for class org.apache.hadoop.hive.ql.exec.NumericUDAFEvaluatorResolver
Constructor.
numInputRowsCntr - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 
numOutputRowsCntr - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 

O

o - Variable in class org.apache.hadoop.hive.serde2.objectinspector.InspectableObject
 
obj - Variable in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
obj - Variable in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
obj - Variable in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
obj1 - Variable in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
obj2 - Variable in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
object - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
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
Category.
ObjectInspectorConverters - Class in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorConverters.
ObjectInspectorConverters.Converter - Interface in org.apache.hadoop.hive.serde2.objectinspector
A converter which will convert objects with one ObjectInspector to another.
ObjectInspectorConverters.IdentityConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
IdentityConverter.
ObjectInspectorConverters.IdentityConverter() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.IdentityConverter
 
ObjectInspectorConverters.ListConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
A converter class for List.
ObjectInspectorConverters.ListConverter(ListObjectInspector, SettableListObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.ListConverter
 
ObjectInspectorConverters.MapConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
A converter class for Map.
ObjectInspectorConverters.MapConverter(MapObjectInspector, SettableMapObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.MapConverter
 
ObjectInspectorConverters.StructConverter - Class in org.apache.hadoop.hive.serde2.objectinspector
A converter class for Struct.
ObjectInspectorConverters.StructConverter(StructObjectInspector, SettableStructObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters.StructConverter
 
ObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
ObjectInspectorFactory.ObjectInspectorOptions - Enum in org.apache.hadoop.hive.serde2.objectinspector
ObjectInspectorOptions describes what ObjectInspector to use.
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.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
 
offline - Variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
oi - Variable in class org.apache.hadoop.hive.serde2.objectinspector.InspectableObject
 
ois - Variable in class org.apache.hadoop.hive.serde2.lazy.objectinspector.LazyUnionObjectInspector
 
onlyContainsPartnCols(Table, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Find out whether the condition only contains partitioned columns.
opClass - Variable in class org.apache.hadoop.hive.ql.exec.OperatorFactory.OpTuple
 
opDisplayName - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
open() - Method in class org.apache.hadoop.hive.common.metrics.Metrics.MetricsScope
Opens scope, and makes note of the time started, increments run counter
openFile(FileSystem, Path, int, long) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Override this method to specialize the type of FSDataInputStream returned.
openNodeScope(Node) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
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 - Variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
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 - Class in org.apache.hadoop.hive.ql.plan.api
 
Operator() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Operator
 
Operator(String, OperatorType, Map<String, String>, Map<String, Long>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Operator
 
Operator(Operator) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Operator
Performs a deep copy on other.
Operator._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Operator.OperatorFunc - Interface in org.apache.hadoop.hive.ql.exec
OperatorFunc.
Operator.ProgressCounter - Enum in org.apache.hadoop.hive.ql.exec
TODO This is a hack for hadoop 0.17 which only supports enum counters.
Operator.State - Enum in org.apache.hadoop.hive.ql.exec
State.
OperatorFactory - Class in org.apache.hadoop.hive.ql.exec
OperatorFactory.
OperatorFactory.OpTuple<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
OpTuple.
OperatorFactory.OpTuple(Class<T>, Class<? extends Operator<T>>) - Constructor for class org.apache.hadoop.hive.ql.exec.OperatorFactory.OpTuple
 
operatorId - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
OperatorType - Enum in org.apache.hadoop.hive.ql.plan.api
 
opName - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
OpParseContext - Class in org.apache.hadoop.hive.ql.parse
Implementation of the Operator Parse Context.
OpParseContext() - Constructor for class org.apache.hadoop.hive.ql.parse.OpParseContext
 
OpParseContext(RowResolver) - Constructor for class org.apache.hadoop.hive.ql.parse.OpParseContext
 
OpProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Operator factory for the rule processors for lineage.
OpProcFactory() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory
 
OpProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.ppr
Operator factory for partition pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators.
OpProcFactory - Class in org.apache.hadoop.hive.ql.ppd
Operator factory for predicate pushdown processing of operator graph Each operator determines the pushdown predicates by walking the expression tree.
OpProcFactory.DefaultLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Default processor.
OpProcFactory.DefaultLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.DefaultLineage
 
OpProcFactory.DefaultPPD - Class in org.apache.hadoop.hive.ql.ppd
Default processor which just merges its children.
OpProcFactory.DefaultPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.DefaultPPD
 
OpProcFactory.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.GroupByLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for GroupBy operator.
OpProcFactory.GroupByLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.GroupByLineage
 
OpProcFactory.JoinLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for Join Operator.
OpProcFactory.JoinLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.JoinLineage
 
OpProcFactory.JoinPPD - Class in org.apache.hadoop.hive.ql.ppd
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.LateralViewForwardPPD - Class in org.apache.hadoop.hive.ql.ppd
 
OpProcFactory.LateralViewForwardPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.LateralViewForwardPPD
 
OpProcFactory.LateralViewJoinLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for Join Operator.
OpProcFactory.LateralViewJoinLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.LateralViewJoinLineage
 
OpProcFactory.ReduceSinkLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
ReduceSink processor.
OpProcFactory.ReduceSinkLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.ReduceSinkLineage
 
OpProcFactory.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.SelectLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for Select operator.
OpProcFactory.SelectLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.SelectLineage
 
OpProcFactory.TableScanLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for TableScan Operator.
OpProcFactory.TableScanLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.TableScanLineage
 
OpProcFactory.TableScanPPD - Class in org.apache.hadoop.hive.ql.ppd
Combines predicates of its child into a single expression and adds a filter op as new child.
OpProcFactory.TableScanPPD() - Constructor for class org.apache.hadoop.hive.ql.ppd.OpProcFactory.TableScanPPD
 
OpProcFactory.TransformLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Processor for Script and UDTF Operators.
OpProcFactory.TransformLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.TransformLineage
 
OpProcFactory.UnionLineage - Class in org.apache.hadoop.hive.ql.optimizer.lineage
Union processor.
OpProcFactory.UnionLineage() - Constructor for class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.UnionLineage
 
oprot_ - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDe
protocols are protected in case any of their properties need to be queried from another class in this package.
opStack - Variable in class org.apache.hadoop.hive.ql.lib.DefaultGraphWalker
 
opStack - Variable in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
 
optimize() - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
Invoke all the transformations one-by-one, and alter the query plan.
optimize() - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalOptimizer
invoke all the resolvers one-by-one, and alter the physical plan.
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.
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(ParseContext) - 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 - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
order - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
Order._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
orderByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.common.metrics - package org.apache.hadoop.hive.common.metrics
 
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.hooks - package org.apache.hadoop.hive.metastore.hooks
 
org.apache.hadoop.hive.metastore.model - package org.apache.hadoop.hive.metastore.model
 
org.apache.hadoop.hive.metastore.parser - package org.apache.hadoop.hive.metastore.parser
This package implements the parser for parsing the string filter for the listPartitionsByFilter API.
org.apache.hadoop.hive.ql - package org.apache.hadoop.hive.ql
 
org.apache.hadoop.hive.ql.exec - package org.apache.hadoop.hive.ql.exec
Hive QL execution tasks, operators, functions and other handlers.
org.apache.hadoop.hive.ql.exec.errors - package org.apache.hadoop.hive.ql.exec.errors
Generates execution error messages using heuristics.
org.apache.hadoop.hive.ql.exec.persistence - package org.apache.hadoop.hive.ql.exec.persistence
 
org.apache.hadoop.hive.ql.history - package org.apache.hadoop.hive.ql.history
 
org.apache.hadoop.hive.ql.hooks - package org.apache.hadoop.hive.ql.hooks
 
org.apache.hadoop.hive.ql.index - package org.apache.hadoop.hive.ql.index
 
org.apache.hadoop.hive.ql.index.compact - package org.apache.hadoop.hive.ql.index.compact
 
org.apache.hadoop.hive.ql.io - package org.apache.hadoop.hive.ql.io
 
org.apache.hadoop.hive.ql.lib - package org.apache.hadoop.hive.ql.lib
 
org.apache.hadoop.hive.ql.lockmgr - package org.apache.hadoop.hive.ql.lockmgr
Hive Lock Manager interfaces and some custom implmentations
org.apache.hadoop.hive.ql.lockmgr.zookeeper - package org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
org.apache.hadoop.hive.ql.log - package org.apache.hadoop.hive.ql.log
 
org.apache.hadoop.hive.ql.metadata - package org.apache.hadoop.hive.ql.metadata
 
org.apache.hadoop.hive.ql.optimizer - package org.apache.hadoop.hive.ql.optimizer
 
org.apache.hadoop.hive.ql.optimizer.lineage - package org.apache.hadoop.hive.ql.optimizer.lineage
 
org.apache.hadoop.hive.ql.optimizer.pcr - package org.apache.hadoop.hive.ql.optimizer.pcr
 
org.apache.hadoop.hive.ql.optimizer.physical - package org.apache.hadoop.hive.ql.optimizer.physical
 
org.apache.hadoop.hive.ql.optimizer.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.plan.api - package org.apache.hadoop.hive.ql.plan.api
 
org.apache.hadoop.hive.ql.ppd - package org.apache.hadoop.hive.ql.ppd
 
org.apache.hadoop.hive.ql.processors - package org.apache.hadoop.hive.ql.processors
 
org.apache.hadoop.hive.ql.security - package org.apache.hadoop.hive.ql.security
 
org.apache.hadoop.hive.ql.security.authorization - package org.apache.hadoop.hive.ql.security.authorization
 
org.apache.hadoop.hive.ql.session - package org.apache.hadoop.hive.ql.session
 
org.apache.hadoop.hive.ql.stats - package org.apache.hadoop.hive.ql.stats
 
org.apache.hadoop.hive.ql.stats.jdbc - package org.apache.hadoop.hive.ql.stats.jdbc
 
org.apache.hadoop.hive.ql.tool - package org.apache.hadoop.hive.ql.tool
 
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
Standard toolkit and framework for generic User-defined functions.
org.apache.hadoop.hive.ql.udf.xml - package org.apache.hadoop.hive.ql.udf.xml
 
org.apache.hadoop.hive.ql.util - package org.apache.hadoop.hive.ql.util
 
org.apache.hadoop.hive.scripts - package org.apache.hadoop.hive.scripts
 
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.proto.test - package org.apache.hadoop.hive.serde2.proto.test
 
org.apache.hadoop.hive.serde2.thrift - package org.apache.hadoop.hive.serde2.thrift
 
org.apache.hadoop.hive.serde2.thrift.test - package org.apache.hadoop.hive.serde2.thrift.test
 
org.apache.hadoop.hive.serde2.thrift_test - package org.apache.hadoop.hive.serde2.thrift_test
 
org.apache.hadoop.hive.serde2.typeinfo - package org.apache.hadoop.hive.serde2.typeinfo
This package provides the implementation of the SerDe type system.
org.apache.hadoop.hive.service - package org.apache.hadoop.hive.service
 
org.apache.hadoop.hive.shims - package org.apache.hadoop.hive.shims
 
org.apache.hadoop.hive.thrift - package org.apache.hadoop.hive.thrift
 
ORIGINAL_LOCATION - Static variable in class org.apache.hadoop.hive.metastore.api.Constants
 
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
 
outExpr - Variable in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.NodeInfoWrapper
 
outPath(String, String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
Given the current configurations (e.g., hadoop version and execution mode), return the correct file name to compare with the current test run output.
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.HashTableSinkDesc
 
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
 
outputObjInspector - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
outputRows - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
outputs - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
List of WriteEntities that are passed to the hooks.
outputs - Variable in class org.apache.hadoop.hive.ql.plan.DDLWork
List of WriteEntities that are passed to the hooks.
outputs - Variable in class org.apache.hadoop.hive.ql.plan.MoveWork
List of WriteEntities that are passed to the hooks.
outputStagePlans(PrintStream, List<Task<? extends Serializable>>, int) - Method in class org.apache.hadoop.hive.ql.exec.ExplainTask
 
outputTestFailureHelpMessage() - Static method in class org.apache.hadoop.hive.ql.QTestUtil
 
outTransport - Variable in class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
ownDeletesAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
ownInsertsAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
ownUpdatesAreVisible(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 

P

PARAMETER_NAME - Static variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
parent - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
 
parse(String, Context) - Method in class org.apache.hadoop.hive.ql.parse.ParseDriver
Parses a command, optionally assigning the parser's token stream to the given context.
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<TableScanOperator, ExprNodeDesc>, HashMap<TableScanOperator, PrunedPartitionList>, 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<AbstractMapJoinOperator<? extends MapJoinDesc>>, Map<GroupByOperator, Set<String>>, Map<String, PrunedPartitionList>, HashMap<TableScanOperator, FilterDesc.sampleDesc>) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseContext
 
ParseDriver - Class in org.apache.hadoop.hive.ql.parse
ParseDriver.
ParseDriver() - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver
 
ParseDriver.ANTLRNoCaseStringStream - Class in org.apache.hadoop.hive.ql.parse
ANTLRNoCaseStringStream.
ParseDriver.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver.ANTLRNoCaseStringStream
 
ParseDriver.HiveLexerX - Class in org.apache.hadoop.hive.ql.parse
HiveLexerX.
ParseDriver.HiveLexerX() - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
ParseDriver.HiveLexerX(CharStream) - Constructor for class org.apache.hadoop.hive.ql.parse.ParseDriver.HiveLexerX
 
ParseDriver.HiveParserX - Class in org.apache.hadoop.hive.ql.parse
HiveParserX.
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.
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.
parseQuery(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
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.
PART_STAT_ID_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
PART_STAT_ROW_COUNT_COLUMN_NAME - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
PART_STAT_TABLE_NAME - Static variable in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsSetupConstants
 
PartExprEvalUtils - Class in org.apache.hadoop.hive.ql.optimizer.ppr
 
PartExprEvalUtils() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.PartExprEvalUtils
 
partHandle - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
partialCopyToStandardObject(List<Object>, Object, int, int, StructObjectInspector, ObjectInspectorUtils.ObjectInspectorCopyOption) - Static method in class org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils
Copy specified fields in the input row to the output array of standard objects.
Partition - Class in org.apache.hadoop.hive.metastore.api
 
Partition() - Constructor for class org.apache.hadoop.hive.metastore.api.Partition
 
Partition(List<String>, String, String, int, int, StorageDescriptor, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.Partition
 
Partition(Partition) - Constructor for class org.apache.hadoop.hive.metastore.api.Partition
Performs a deep copy on other.
Partition - Class in org.apache.hadoop.hive.ql.metadata
A Hive Table Partition: is a fundamental storage unit within a Table.
Partition() - Constructor for class org.apache.hadoop.hive.ql.metadata.Partition
Used only for serialization.
Partition(Table) - Constructor for class org.apache.hadoop.hive.ql.metadata.Partition
create an empty partition.
Partition(Table, Partition) - Constructor for class org.apache.hadoop.hive.ql.metadata.Partition
 
Partition(Table, Map<String, String>, Path) - Constructor for class org.apache.hadoop.hive.ql.metadata.Partition
Create partition object with the given info.
Partition._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
partition_name_to_spec(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
partition_name_to_spec(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
partition_name_to_spec(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
partition_name_to_spec(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
partition_name_to_spec(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
partition_name_to_vals(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
partition_name_to_vals(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
partition_name_to_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
partition_name_to_vals(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
partition_name_to_vals(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
PartitionConditionRemover - Class in org.apache.hadoop.hive.ql.optimizer.pcr
The transformation step that does partition condition remover.
PartitionConditionRemover() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PartitionConditionRemover
 
PartitionDesc - Class in org.apache.hadoop.hive.ql.plan
PartitionDesc.
PartitionDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
PartitionDesc(TableDesc, LinkedHashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
PartitionDesc(TableDesc, LinkedHashMap<String, String>, Class<? extends Deserializer>, Class<? extends InputFormat>, Class<?>, Properties, String) - Constructor for class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
PartitionDesc(Partition) - 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).
partitionLocation() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionNameToSpec(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
partitionNameToSpec(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
partitionNameToVals(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
partitionNameToVals(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
PartitionPruner - Class in org.apache.hadoop.hive.ql.optimizer.ppr
The transformation step that does partition pruning.
PartitionPruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
partitions - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
partitionSpec() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partitionTester(HiveMetaStoreClient, HiveConf) - Static method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
partitionVal() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
partSpec - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
partTypeExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
passExecContext(ExecMapperContext) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Pass the execContext reference to every child operator
pathid - Variable in class org.apache.hadoop.hive.ql.Context
 
pathToPartitionInfo - Variable in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
pattern - Static variable in class org.apache.hadoop.hive.scripts.extracturl
 
PcrExprProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.pcr
The processor context for partition condition remover.
PcrExprProcCtx(String, List<Partition>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
PcrExprProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Expression processor factory for partition condition removing.
PcrExprProcFactory.ColumnExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Processor for column expressions.
PcrExprProcFactory.ColumnExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.ColumnExprProcessor
 
PcrExprProcFactory.DefaultExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Processor for constants and null expressions.
PcrExprProcFactory.DefaultExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.DefaultExprProcessor
 
PcrExprProcFactory.FieldExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.pcr
FieldExprProcessor.
PcrExprProcFactory.FieldExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.FieldExprProcessor
 
PcrExprProcFactory.GenericFuncExprProcessor - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Processor for Generic functions If it is AND, OR or NOT, we replace the node to be the constant true or false if we are sure the result from children, or cut one of the child if we know partial results.
PcrExprProcFactory.GenericFuncExprProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.GenericFuncExprProcessor
 
PcrExprProcFactory.NodeInfoWrapper - Class in org.apache.hadoop.hive.ql.optimizer.pcr
 
PcrExprProcFactory.NodeInfoWrapper(PcrExprProcFactory.WalkState, Boolean[], ExprNodeDesc) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.NodeInfoWrapper
 
PcrExprProcFactory.WalkState - Enum in org.apache.hadoop.hive.ql.optimizer.pcr
 
PcrOpProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.pcr
PcrOpProcFactory contains processors that process expression tree of filter operators following table scan operators.
PcrOpProcFactory.DefaultPCR - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Default processor which does nothing
PcrOpProcFactory.DefaultPCR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory.DefaultPCR
 
PcrOpProcFactory.FilterPCR - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Remove partition condition in a filter operator when possible.
PcrOpProcFactory.FilterPCR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory.FilterPCR
 
PcrOpWalkerCtx - Class in org.apache.hadoop.hive.ql.optimizer.pcr
Context class for operator tree walker for partition condition remover.
PcrOpWalkerCtx(ParseContext, List<PcrOpWalkerCtx.OpToDeleteInfo>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx
Constructor.
PcrOpWalkerCtx.OpToDeleteInfo - Class in org.apache.hadoop.hive.ql.optimizer.pcr
 
PcrOpWalkerCtx.OpToDeleteInfo(Operator<? extends Serializable>, FilterOperator) - Constructor for class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpWalkerCtx.OpToDeleteInfo
 
peekNode() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
performRCFileFullyReadColumnTest(FileSystem, Path, int, boolean) - Method in class org.apache.hadoop.hive.ql.io.PerformTestRCFileAndSeqFile
 
performRCFileReadFirstAndLastColumnTest(FileSystem, Path, int, boolean) - Method in class org.apache.hadoop.hive.ql.io.PerformTestRCFileAndSeqFile
 
performRCFileReadFirstColumnTest(FileSystem, Path, int, boolean) - Method in class org.apache.hadoop.hive.ql.io.PerformTestRCFileAndSeqFile
 
performSequenceFileRead(FileSystem, int, Path) - Method in class org.apache.hadoop.hive.ql.io.PerformTestRCFileAndSeqFile
 
PerformTestRCFileAndSeqFile - Class in org.apache.hadoop.hive.ql.io
PerformTestRCFileAndSeqFile.
PerformTestRCFileAndSeqFile(boolean, String) - Constructor for class org.apache.hadoop.hive.ql.io.PerformTestRCFileAndSeqFile
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.ColumnPruner
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer.BucketGroupByProcessor
 
pGraphContext - Variable in class org.apache.hadoop.hive.ql.optimizer.ReduceSinkDeDuplication
 
PhysicalContext - Class in org.apache.hadoop.hive.ql.optimizer.physical
physical context used by physical resolvers.
PhysicalContext(HiveConf, ParseContext, Context, List<Task<? extends Serializable>>, Task<? extends Serializable>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
PhysicalOptimizer - Class in org.apache.hadoop.hive.ql.optimizer.physical
A hierarchy physical optimizer, which contains a list of PhysicalPlanResolver.
PhysicalOptimizer(PhysicalContext, HiveConf) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalOptimizer
 
PhysicalPlanResolver - Interface in org.apache.hadoop.hive.ql.optimizer.physical
Physical plan optimization interface.
PidDailyRollingFileAppender - Class in org.apache.hadoop.hive.ql.log
 
PidDailyRollingFileAppender() - Constructor for class org.apache.hadoop.hive.ql.log.PidDailyRollingFileAppender
 
PlanUtils - Class in org.apache.hadoop.hive.ql.plan
PlanUtils.
PlanUtils.ExpressionTypes - Enum in org.apache.hadoop.hive.ql.plan
ExpressionTypes.
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
PLUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
pollTasks(Set<TaskResult>) - Method in class org.apache.hadoop.hive.ql.Driver
Polls running tasks to see if a task has ended.
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>>, Byte[], int) - Static method in class org.apache.hadoop.hive.ql.exec.JoinUtil
 
posBigTable - Variable in class org.apache.hadoop.hive.ql.exec.AbstractMapJoinOperator
 
posBigTableAlias - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
posBigTableTag - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.metadata.DummySemanticAnalyzerHook
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.metadata.DummySemanticAnalyzerHook1
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.parse.AbstractSemanticAnalyzerHook
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHook
Invoked after Hive performs its own semantic analysis on a statement (including optimization).
PostExecute - Interface in org.apache.hadoop.hive.ql.hooks
The post execute hook interface.
PostExecutePrinter - Class in org.apache.hadoop.hive.ql.hooks
Implementation of a post execute hook that simply prints out its parameters to standard output.
PostExecutePrinter() - Constructor for class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter
 
PostExecutePrinter.DependencyKeyComp - Class in org.apache.hadoop.hive.ql.hooks
 
PostExecutePrinter.DependencyKeyComp() - Constructor for class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter.DependencyKeyComp
 
postHook(Set<String>, String) - Method in interface org.apache.hadoop.hive.ql.session.SessionState.ResourceHook
 
postTest(HiveConf) - Method in class org.apache.hadoop.hive.ql.QTestUtil.QTestSetup
 
preAnalyze(HiveSemanticAnalyzerHookContext, ASTNode) - Method in class org.apache.hadoop.hive.ql.metadata.DummySemanticAnalyzerHook
 
preAnalyze(HiveSemanticAnalyzerHookContext, ASTNode) - Method in class org.apache.hadoop.hive.ql.metadata.DummySemanticAnalyzerHook1
 
preAnalyze(HiveSemanticAnalyzerHookContext, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.AbstractSemanticAnalyzerHook
 
preAnalyze(HiveSemanticAnalyzerHookContext, ASTNode) - Method in interface org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHook
Invoked before Hive performs its own semantic analysis on a statement.
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
 
preCreateTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called before a new table definition is added to the metastore during CREATE TABLE.
PredicatePushDown - Class in org.apache.hadoop.hive.ql.ppd
Implements predicate pushdown.
PredicatePushDown() - Constructor for class org.apache.hadoop.hive.ql.ppd.PredicatePushDown
 
preDropTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called before a table definition is removed from the metastore during DROP TABLE.
PreExecute - Interface in org.apache.hadoop.hive.ql.hooks
The pre execute hook interface.
PreExecutePrinter - Class in org.apache.hadoop.hive.ql.hooks
Implementation of a pre execute hook that simply prints out its parameters to standard output.
PreExecutePrinter() - Constructor for class org.apache.hadoop.hive.ql.hooks.PreExecutePrinter
 
preferWritable() - Method in class org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive.AbstractPrimitiveLazyObjectInspector
 
preferWritable() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveJavaObjectInspector
 
preferWritable() - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.AbstractPrimitiveWritableObjectInspector
 
preferWritable() - Method in interface org.apache.hadoop.hive.serde2.objectinspector.PrimitiveObjectInspector
Whether the ObjectInspector prefers to return a Primitive Writable Object instead of a Primitive Java Object.
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.
preTest(HiveConf) - Method in class org.apache.hadoop.hive.ql.QTestUtil.QTestSetup
 
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.HiveBaseResultSet
 
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.
PrimitiveObjectInspector.PrimitiveCategory - Enum in org.apache.hadoop.hive.serde2.objectinspector
The primitive types supported by Hive.
PrimitiveObjectInspectorConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
PrimitiveObjectInspectorConverter.
PrimitiveObjectInspectorConverter() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter
 
PrimitiveObjectInspectorConverter.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.StringConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A helper class to convert any primitive to String.
PrimitiveObjectInspectorConverter.StringConverter(PrimitiveObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.StringConverter
 
PrimitiveObjectInspectorConverter.TextConverter - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
A helper class to convert any primitive to Text.
PrimitiveObjectInspectorConverter.TextConverter(PrimitiveObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorConverter.TextConverter
 
PrimitiveObjectInspectorFactory - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
PrimitiveObjectInspectorFactory is the primary way to create new PrimitiveObjectInspector instances.
PrimitiveObjectInspectorUtils - Class in org.apache.hadoop.hive.serde2.objectinspector.primitive
ObjectInspectorFactory is the primary way to create new ObjectInspector instances.
PrimitiveObjectInspectorUtils.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.
PrincipalDesc - Class in org.apache.hadoop.hive.ql.plan
 
PrincipalDesc(String, PrincipalType) - Constructor for class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
PrincipalDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
principalName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PrincipalPrivilegeSet - Class in org.apache.hadoop.hive.metastore.api
 
PrincipalPrivilegeSet() - Constructor for class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
PrincipalPrivilegeSet(Map<String, List<PrivilegeGrantInfo>>, Map<String, List<PrivilegeGrantInfo>>, Map<String, List<PrivilegeGrantInfo>>) - Constructor for class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
PrincipalPrivilegeSet(PrincipalPrivilegeSet) - Constructor for class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
Performs a deep copy on other.
PrincipalPrivilegeSet._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
principalSpecification() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PrincipalType - Enum in org.apache.hadoop.hive.metastore.api
 
print(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.
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
Privilege - Class in org.apache.hadoop.hive.ql.security.authorization
Privilege defines a privilege in Hive.
Privilege(Privilege.PrivilegeType) - Constructor for class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
Privilege() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
Privilege.PrivilegeType - Enum in org.apache.hadoop.hive.ql.security.authorization
 
PrivilegeBag - Class in org.apache.hadoop.hive.metastore.api
 
PrivilegeBag() - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
PrivilegeBag(List<HiveObjectPrivilege>) - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
PrivilegeBag(PrivilegeBag) - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeBag
Performs a deep copy on other.
PrivilegeBag._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PrivilegeDesc - Class in org.apache.hadoop.hive.ql.plan
 
PrivilegeDesc(Privilege, List<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
PrivilegeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
PrivilegeGrantInfo - Class in org.apache.hadoop.hive.metastore.api
 
PrivilegeGrantInfo() - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
PrivilegeGrantInfo(String, int, String, PrincipalType, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
PrivilegeGrantInfo(PrivilegeGrantInfo) - Constructor for class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
Performs a deep copy on other.
PrivilegeGrantInfo._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
privilegeIncludeColObject() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
privilegeList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
privilegeObject() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
PrivilegeObjectDesc - Class in org.apache.hadoop.hive.ql.plan
 
PrivilegeObjectDesc(boolean, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
PrivilegeObjectDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
PrivilegeRegistry - Class in org.apache.hadoop.hive.ql.security.authorization
PrivilegeRegistry is used to do privilege lookups.
PrivilegeRegistry() - Constructor for class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
PrivilegeScope - Enum in org.apache.hadoop.hive.ql.security.authorization
PrivilegeScope describes a hive defined privilege's scope (global/database/table/column).
privilegeType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
privlegeDef() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
process(TProtocol, TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor
 
process(Writable) - 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(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in interface org.apache.hadoop.hive.ql.lib.NodeProcessor
Generic process for all ops that don't have specific implementations.
process(WatchedEvent) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager.DummyWatcher
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.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.ColumnPrunerLateralViewJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.ColumnPrunerMapJoinProc
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPrunerProcFactory.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.GroupByOptimizer.BucketGroupByProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.ColumnExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.ExprProcFactory.GenericExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.DefaultLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.GroupByLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.JoinLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.LateralViewJoinLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.ReduceSinkLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.SelectLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.TableScanLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.TransformLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.OpProcFactory.UnionLineage
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.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.pcr.PcrExprProcFactory.ColumnExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.DefaultExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.FieldExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.GenericFuncExprProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory.DefaultPCR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrOpProcFactory.FilterPCR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.LocalMapJoinProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.LocalMapJoinProcFactory.MapJoinFollowByProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory.SkewJoinDefaultProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory.SkewJoinJoinProcessor
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.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.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.SamplePruner.DefaultPPR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.FilterPPR
 
process(Node, Stack<Node>, NodeProcessorCtx, Object...) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.MapJoinUnion
 
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.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.LateralViewForwardPPD
 
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(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Give a set of arguments for the UDTF to process.
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
process(Object[]) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
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
 
processFile(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.
processInitFiles(CliSessionState) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processLine(String) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processLogLine(String) - Method in interface org.apache.hadoop.hive.ql.exec.errors.ErrorHeuristic
Process the given log line.
processLogLine(String) - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ExtractOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.FilterOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ForwardOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.GroupByOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.HashTableDummyOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.JoinOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.LateralViewForwardOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.LateralViewJoinOperator
An important assumption for processOp() is that for a given row from the TS, the LVJ will first get the row from the left select operator, followed by all the corresponding rows from the UDTF operator.
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.LimitOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.MapOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Process the row.
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.SelectOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
Other than gathering statistics for the ANALYZE command, the table scan operator does not do anything special other than just forwarding the row.
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
processOp(Object, int) - Method in class org.apache.hadoop.hive.ql.exec.UnionOperator
 
processReader(BufferedReader) - Method in class org.apache.hadoop.hive.cli.CliDriver
 
processSkewJoin(JoinOperator, Task<? extends Serializable>, ParseContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.GenMRSkewJoinProcessor
Create tasks for processing skew joins.
progress - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
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
 
property - Variable in class org.apache.hadoop.hive.ant.GetVersionPref
The name of the property that gets the version prefix.
ProtectMode - Class in org.apache.hadoop.hive.metastore
 
ProtectMode() - Constructor for class org.apache.hadoop.hive.metastore.ProtectMode
 
prune(Table, ExprNodeDesc, HiveConf, String, Map<String, PrunedPartitionList>) - Static method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
Get the partition list for the table that satisfies the partition pruner condition.
prune(Partition, FilterDesc.sampleDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
Prunes to get all the files in the partition that satisfy the TABLESAMPLE clause.
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
 
publishStat(String, String, String) - Method in class org.apache.hadoop.hive.ql.stats.jdbc.JDBCStatsPublisher
 
publishStat(String, String, String) - Method in interface org.apache.hadoop.hive.ql.stats.StatsPublisher
This method publishes a given statistic into a disk storage, possibly HBase or MySQL.
pushedPredicate - Variable in class org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler.DecomposedPredicate
Portion of predicate to be evaluated by storage handler.
pushFeed(Task.FeedType, Object) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
pushFilters(JobConf, TableScanOperator) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
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
 
pushProjectionsAndFilters(JobConf, Class, String, String) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
pushProjectionsAndFilters(JobConf, Class, String, String, boolean) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat
 
put(String, Object) - Method in interface org.apache.hadoop.hive.common.metrics.MetricsMBean
Add a key/metric and its value to track
put(String, Object) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
put(Integer, HashTableSinkOperator.HashTableSinkObjectCtx) - Static method in class org.apache.hadoop.hive.ql.exec.MapJoinMetaData
 
put(K, V) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
put(T) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MRU
Insert a value into the MRU.
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, Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableMapObjectInspector
Add a key-value pair to the map.
put(Object, Object, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
putColumnLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
putDBLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
putDependency(LineageInfo.DataContainer, FieldSchema, LineageInfo.Dependency) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo
Puts the dependency for a table, column tuple.
putDependency(Operator<? extends Serializable>, ColumnInfo, LineageInfo.Dependency) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.LineageCtx.Index
Puts the dependency for an operator, columninfo tuple.
putExpression(ASTNode, ColumnInfo) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
Puts a resolver entry corresponding to a source expression which is to be used for identical expression recognition (e.g.
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
 
putTableLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
putToGroupPrivileges(String, List<PrivilegeGrantInfo>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
putToMStringString(String, String) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
putToOperatorAttributes(String, String) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
putToOperatorCounters(String, long) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
putToParameters(String, String) - Method in class org.apache.hadoop.hive.metastore.api.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
 
putToQueryAttributes(String, String) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
putToQueryCounters(String, long) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
putToRolePrivileges(String, List<PrivilegeGrantInfo>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
putToStageAttributes(String, String) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
putToStageCounters(String, long) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
putToSuccess(String, Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
putToSuccess(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
putToTaskAttributes(String, String) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
putToTaskCounters(String, long) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
putToUserPrivileges(String, List<PrivilegeGrantInfo>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
putUserLevelRequiredPriv(Privilege[], Privilege[]) - Method in class org.apache.hadoop.hive.ql.plan.HiveOperation.PrivilegeAgreement
 
pvalMatches(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
Returns true if partial has the same values as full for all values that aren't empty in partial.

Q

QB - Class in org.apache.hadoop.hive.ql.parse
Implementation of the query block.
QB() - Constructor for class org.apache.hadoop.hive.ql.parse.QB
 
QB(String, String, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.QB
 
QBExpr - Class in org.apache.hadoop.hive.ql.parse
Implementation of the query block expression.
QBExpr(String) - Constructor for class org.apache.hadoop.hive.ql.parse.QBExpr
 
QBExpr(QB) - Constructor for class org.apache.hadoop.hive.ql.parse.QBExpr
 
QBExpr(QBExpr.Opcode, QBExpr, QBExpr) - Constructor for class org.apache.hadoop.hive.ql.parse.QBExpr
 
QBExpr.Opcode - Enum in org.apache.hadoop.hive.ql.parse
Opcode.
QBJoinTree - Class in org.apache.hadoop.hive.ql.parse
Internal representation of the join tree.
QBJoinTree() - Constructor for class org.apache.hadoop.hive.ql.parse.QBJoinTree
constructor.
QBMetaData - Class in org.apache.hadoop.hive.ql.parse
Implementation of the metadata information related to a query block.
QBMetaData() - Constructor for class org.apache.hadoop.hive.ql.parse.QBMetaData
 
QBParseInfo - Class in org.apache.hadoop.hive.ql.parse
Implementation of the parse information related to a query block.
QBParseInfo(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
QTestGenTask - Class in org.apache.hadoop.hive.ant
 
QTestGenTask() - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask
 
QTestGenTask.DisabledQFileFilter - Class in org.apache.hadoop.hive.ant
 
QTestGenTask.DisabledQFileFilter() - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask.DisabledQFileFilter
 
QTestGenTask.QFileFilter - Class in org.apache.hadoop.hive.ant
 
QTestGenTask.QFileFilter() - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask.QFileFilter
 
QTestGenTask.QFileRegexFilter - Class in org.apache.hadoop.hive.ant
 
QTestGenTask.QFileRegexFilter(String) - Constructor for class org.apache.hadoop.hive.ant.QTestGenTask.QFileRegexFilter
 
QTestUtil - Class in org.apache.hadoop.hive.ql
QTestUtil.
QTestUtil(String, String) - Constructor for class org.apache.hadoop.hive.ql.QTestUtil
 
QTestUtil(String, String, boolean, String) - Constructor for class org.apache.hadoop.hive.ql.QTestUtil
 
QTestUtil.QTestSetup - Class in org.apache.hadoop.hive.ql
QTestSetup defines test fixtures which are reused across testcases, and are needed before any test can be run
QTestUtil.QTestSetup() - Constructor for class org.apache.hadoop.hive.ql.QTestUtil.QTestSetup
 
QTestUtil.QTRunner - Class in org.apache.hadoop.hive.ql
QTRunner: Runnable class for running a a single query file.
QTestUtil.QTRunner(QTestUtil, String) - Constructor for class org.apache.hadoop.hive.ql.QTestUtil.QTRunner
 
quantile(double) - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Gets an approximate quantile value from the current histogram.
quantilesOI - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
Query - Class in org.apache.hadoop.hive.ql.plan.api
 
Query() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Query
 
Query(String, String, Map<String, String>, Map<String, Long>, Graph, List<Stage>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Query
 
Query(Query) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Query
Performs a deep copy on other.
Query._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
queryListRunner(File[], String[], String[], boolean, Test) - Static method in class org.apache.hadoop.hive.ql.QTestUtil
executes a set of query files either in sequence or in parallel.
queryOperator() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
queryPlan - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
QueryPlan - Class in org.apache.hadoop.hive.ql.plan.api
 
QueryPlan() - Constructor for class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
QueryPlan(List<Query>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
QueryPlan(QueryPlan) - Constructor for class org.apache.hadoop.hive.ql.plan.api.QueryPlan
Performs a deep copy on other.
QueryPlan - Class in org.apache.hadoop.hive.ql
QueryPlan can be serialized to disk so that we can restart/resume the progress of it in the future, either within or outside of the current jvm.
QueryPlan() - Constructor for class org.apache.hadoop.hive.ql.QueryPlan
 
QueryPlan(String, BaseSemanticAnalyzer) - Constructor for class org.apache.hadoop.hive.ql.QueryPlan
 
QueryPlan._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
queued - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
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

r - Variable in class org.apache.hadoop.hive.ql.exec.TestExpressionEvaluator
 
r - Variable in class org.apache.hadoop.hive.ql.exec.TestOperators
 
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
 
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.
RCFILE_INPUT - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
RCFILE_OUTPUT - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
RCFileCat - Class in org.apache.hadoop.hive.cli
 
RCFileCat() - Constructor for class org.apache.hadoop.hive.cli.RCFileCat
 
RCFileInputFormat<K extends org.apache.hadoop.io.LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hadoop.hive.ql.io
RCFileInputFormat.
RCFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.RCFileInputFormat
 
RCFileOutputFormat - Class in org.apache.hadoop.hive.ql.io
RCFileOutputFormat.
RCFileOutputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
 
RCFileRecordReader<K extends org.apache.hadoop.io.LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hadoop.hive.ql.io
RCFileRecordReader.
RCFileRecordReader(Configuration, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.RCFileRecordReader
 
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 exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
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.HiveObjectPrivilege
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
read(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
read(TProtocol) - Method in 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.PrincipalPrivilegeSet
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
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_index_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_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_index_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_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_all_databases_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.ThriftHiveMetastore.grant_privileges_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.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.ql.plan.api.Adjacency
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
read(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
read() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
read(char[], int, int) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
read() - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
 
read(boolean) - Method in class org.apache.hadoop.hive.serde2.binarysortable.InputByteBuffer
Read one byte from the byte buffer.
read(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
read(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
read(TProtocol) - Method in class org.apache.hadoop.hive.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.getQueryPlan_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
read(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
READ_COLUMN_IDS_CONF_STR - Static variable in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
 
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() - 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() - Constructor for class org.apache.hadoop.hive.ql.hooks.ReadEntity
For serialization only.
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.persistence.AbstractMapJoinKey
 
readExternal(ObjectInput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
readExternal(ObjectInput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
readExternal(ObjectInput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
readExternal(ObjectInput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
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.BucketizedHiveInputSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Writable interface.
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
 
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
 
readFields(DataInput) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
 
readFields(DataInput) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
 
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.
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.
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
 
readOnly - Variable in class org.apache.hadoop.hive.metastore.ProtectMode
 
readProps(ASTNode, Map<String, String>) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Converts parsed key/value properties pairs into a map.
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.
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.
ready() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
realFile(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Shamelessly cloned from GenericOptionsParser.
receiveFeed(Task.FeedType, Object) - Method in class org.apache.hadoop.hive.ql.exec.StatsTask
 
receiveFeed(Task.FeedType, Object) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
RECORD_INTERVAL_CONF_STR - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
 
RecordReader - Interface in org.apache.hadoop.hive.ql.exec
RecordReader.
recordReader() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RecordTestObj - Class in org.apache.hadoop.hive.ql.io
 
RecordTestObj() - Constructor for class org.apache.hadoop.hive.ql.io.RecordTestObj
 
RecordTestObj(String, long) - Constructor for class org.apache.hadoop.hive.ql.io.RecordTestObj
 
RecordTestObj.Comparator - Class in org.apache.hadoop.hive.ql.io
 
RecordTestObj.Comparator() - Constructor for class org.apache.hadoop.hive.ql.io.RecordTestObj.Comparator
 
RecordWriter - Interface in org.apache.hadoop.hive.ql.exec
RecordWriter.
recordWriter() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_add_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_database() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_alter_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_append_partition_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_cancel_delegation_token() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_database() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_create_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_index_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_partition_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_drop_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_all_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_all_tables() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_config_value() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_database() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_delegation_token() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_delegation_token_with_signature() - 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_index_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_index_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_by_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_names_ps() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partition_with_auth() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_by_filter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_ps() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_ps_with_auth() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_partitions_with_auth() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_privilege_set() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_role_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_schema() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_get_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_getQueryPlan() - 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
 
recv_grant_privileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_grant_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_list_privileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_list_roles() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_partition_name_to_spec() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_partition_name_to_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_renew_delegation_token() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_revoke_privileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
recv_revoke_role() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
reduce(Object, Iterator, OutputCollector, Reporter) - Method in class org.apache.hadoop.hive.ql.exec.ExecReducer
 
reduceDone() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
reduceDone() - Method in class org.apache.hadoop.hive.ql.exec.MapRedTask
 
reduceProgress - Variable in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
ReduceSinkDeDuplication - Class in org.apache.hadoop.hive.ql.optimizer
If two reducer sink operators share the same partition/sort columns, we should merge them.
ReduceSinkDeDuplication() - Constructor for class org.apache.hadoop.hive.ql.optimizer.ReduceSinkDeDuplication
 
ReduceSinkDesc - Class in org.apache.hadoop.hive.ql.plan
ReduceSinkDesc.
ReduceSinkDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
ReduceSinkDesc(ArrayList<ExprNodeDesc>, int, ArrayList<ExprNodeDesc>, ArrayList<String>, List<List<Integer>>, ArrayList<String>, int, ArrayList<ExprNodeDesc>, int, TableDesc, TableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
ReduceSinkOperator - Class in org.apache.hadoop.hive.ql.exec
Reduce Sink Operator sends output to the reduce stage.
ReduceSinkOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ReduceSinkOperator
 
reduceStarted() - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
reduceStarted() - Method in class org.apache.hadoop.hive.ql.exec.MapRedTask
 
ReflectionStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
ReflectionStructObjectInspector works on struct data that is stored as a native Java object.
ReflectionStructObjectInspector.MyField - Class in org.apache.hadoop.hive.serde2.objectinspector
MyField.
ReflectionStructObjectInspector.MyField(Field, ObjectInspector) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector.MyField
 
refreshRow() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
RegexComponent - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
RegexErrorHeuristic - Class in org.apache.hadoop.hive.ql.exec.errors
Simple heuristic where the query and the lines of the task log file are run through regular expressions to see if they resemble a known error condition.
RegexErrorHeuristic() - Constructor for class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
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
 
registerGenericUDTF(boolean, String, Class<? extends GenericUDTF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerInputFormatChecker(Class<? extends InputFormat>, Class<? extends InputFormatChecker>) - Static method in class org.apache.hadoop.hive.ql.io.HiveFileFormatUtils
register an InputFormatChecker for a given InputFormat.
registerJar(String) - Static method in class org.apache.hadoop.hive.ql.session.SessionState
 
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
 
registerTemporaryGenericUDTF(String, Class<? extends GenericUDTF>) - 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>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDAF(boolean, String, Class<? extends UDAF>) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDF(boolean, String, Class<? extends UDF>, boolean) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDF(String, Class<? extends UDF>, boolean, String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registerUDF(boolean, String, Class<? extends UDF>, boolean, String) - Static method in class org.apache.hadoop.hive.ql.exec.FunctionRegistry
 
registry - Static variable in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
Registry - Static variable in class org.apache.hadoop.hive.ql.security.authorization.PrivilegeRegistry
 
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.
relative(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
releaseAllLocks(HiveConf) - Static method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
releaseLocks(List<HiveLock>) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
releaseLocks(List<HiveLock>) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
releaseSavepoint(Savepoint) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
remove() - Method in class org.apache.hadoop.hive.ql.exec.persistence.DCLLItem
Remove the current item from the doubly circular linked list.
remove(K) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
remove(T) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MRU
Remove a item from the MRU list.
remove(Object, Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableMapObjectInspector
Remove a key-value pair from the map.
remove(Object, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardMapObjectInspector
 
removeChild(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
removeChildAndAdoptItsChildren(Operator<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Remove a child and add all of the child's children to the location of the child
removeDependentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
Remove the dependent task.
removeFromChildrenTasks() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
removeFromClassPath(String[]) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
remove elements from the classpath.
removeFromRootTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
removeQuery(int) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Removes a query from the execution list.
removeRole(String) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
removeRole(String) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
removeTempOrDuplicateFiles(FileSystem, Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Remove all temporary files and duplicate (double-committed) files from a given directory.
removeTempOrDuplicateFiles(FileSystem, Path, DynamicPartitionCtx) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Remove all temporary files and duplicate (double-committed) files from a given directory.
removeTempOrDuplicateFiles(FileStatus[], FileSystem) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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.
renderOrigin(StringBuilder, ASTNodeOrigin) - Static method in enum org.apache.hadoop.hive.ql.parse.ErrorMsg
 
renew_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.renew_delegation_token_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
renew_delegation_token(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.renew_delegation_token_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
renew_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
renew_delegation_token(String) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
renew_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
renewDelegationToken(String) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Renew a delegation token to extend its lifetime.
renewDelegationToken(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
renewDelegationToken(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
renewDelegationToken(String) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
reopen() - Method in class org.apache.hadoop.hive.common.metrics.Metrics.MetricsScope
Closes scope if open, and reopens it
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, Path, Configuration) - Static method in class org.apache.hadoop.hive.ql.metadata.Hive
Replaces files in the partition with new data set specified by srcf.
replaceFiles(Path) - Method in class org.apache.hadoop.hive.ql.metadata.Table
Replaces the directory corresponding to the table 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.
replaceTaskIdFromFilename(String, int) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Replace the task id from the filename.
reporter - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
reporter - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
reportProgress() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
requiredness - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.DynamicSerDeFieldRequiredness
Is this a required, skippable or optional field.
reservedPartitionValues - Static variable in class org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer
 
reset(byte[], int, int) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
 
reset() - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayOutputStream
reset() - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
Resets to state before any processLogLine() calls.
reset() - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
reset(MapJoinRowContainer<Object[]>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
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.GenericUDAFCollectSet.GenericUDAFMkSetEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Reset the aggregation.
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
reset(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.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() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Resets an n-gram estimator object to its initial state.
reset() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
Resets a histogram object to its initial state.
reset() - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
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.Operator
 
resetId() - Static method in class org.apache.hadoop.hive.ql.exec.TaskFactory
 
resetLastEnumUsed() - Static method in class org.apache.hadoop.hive.ql.exec.Operator
 
resetParser() - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
resetRow() - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
Reset the execution context for each new row.
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.
residualPredicate - Variable in class org.apache.hadoop.hive.ql.metadata.HiveStoragePredicateHandler.DecomposedPredicate
Portion of predicate to be post-evaluated by Hive for any rows which are returned by storage handler.
resize(Object, int) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableListObjectInspector
Resize the list.
resize(Object, int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.CommonJoinResolver
 
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver
 
resolve(PhysicalContext) - Method in interface org.apache.hadoop.hive.ql.optimizer.physical.PhysicalPlanResolver
All physical plan resolvers have to implement this entry method.
resolve(PhysicalContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver
 
restoreOriginalTracker() - Method in class org.apache.hadoop.hive.ql.Context
 
result - Variable in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
result - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
ResultVector - Variable in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.NodeInfoWrapper
 
retrieve(InspectableObject) - Method in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
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
 
revoke_privileges(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_privileges_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
revoke_privileges(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_privileges_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
revoke_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
revoke_privileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
revoke_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
revoke_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
revoke_privileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
revoke_role(String, String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_role_call>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
revoke_role(String, String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_role_call>) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface
 
revoke_role(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
revoke_role(String, String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
 
revoke_role(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
revoke_role(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
revoke_role(String, String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
RevokeDesc - Class in org.apache.hadoop.hive.ql.plan
 
RevokeDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
RevokeDesc(List<PrivilegeDesc>, List<PrincipalDesc>, PrivilegeObjectDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
revokePrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
revokePrivileges(PrivilegeBag) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
revokePrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
revokePrivileges() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
revokeRole(Role, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
revokeRole(Role, String, PrincipalType) - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
revokeRole(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
revokeRole() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
rewriteViewToSubq(String, String, QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
RIGHT_OUTER_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
Role - Class in org.apache.hadoop.hive.metastore.api
 
Role() - Constructor for class org.apache.hadoop.hive.metastore.api.Role
 
Role(String, int, String) - Constructor for class org.apache.hadoop.hive.metastore.api.Role
 
Role(Role) - Constructor for class org.apache.hadoop.hive.metastore.api.Role
Performs a deep copy on other.
Role._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RoleDDLDesc - Class in org.apache.hadoop.hive.ql.plan
 
RoleDDLDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
RoleDDLDesc(String, RoleDDLDesc.RoleOperation) - Constructor for class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
RoleDDLDesc(String, PrincipalType, RoleDDLDesc.RoleOperation, String) - Constructor for class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
RoleDDLDesc.RoleOperation - Enum in org.apache.hadoop.hive.ql.plan
 
rollback() - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
rollback(Savepoint) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
rollbackCreateTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called after failure adding a new table definition to the metastore during CREATE TABLE.
rollbackDropTable(Table) - Method in interface org.apache.hadoop.hive.metastore.HiveMetaHook
Called after failure removing a table definition from the metastore during DROP TABLE.
rollbackTransaction() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
Rolls back the current transaction if it is active
rollbackTransaction() - Method in interface org.apache.hadoop.hive.metastore.RawStore
Rolls back the current transaction if it is active
rootNode() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.JJTthrift_grammarState
 
rootTasks - Variable in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
rootTasks - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
row - Variable in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
ROW_COUNT - Static variable in class org.apache.hadoop.hive.ql.stats.StatsSetupConst
The name of the statistic Row Count to be published or gathered.
RowContainer<Row extends List<Object>> - Class in org.apache.hadoop.hive.ql.exec.persistence
Simple persistent container for rows.
RowContainer() - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
RowContainer(Configuration) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
RowContainer(int, Configuration) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
RowContainer(int, SerDe, ObjectInspector, Configuration) - Constructor for class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
rowContainerMap - Variable in class org.apache.hadoop.hive.ql.exec.MapJoinOperator
 
rowContainerStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
The standard ObjectInspectors for the row container.
rowContainerStandardObjectInspectors - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
rowCountMap - Variable in class org.apache.hadoop.hive.ql.history.HiveHistory.QueryInfo
 
rowDeleted() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
rowFormat() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
rowFormatDelimited() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
rowFormatSerde() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
rowInserted() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
rowList - Variable in class org.apache.hadoop.hive.ql.exec.CollectOperator
 
rowOutWriters - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
RowResolver - Class in org.apache.hadoop.hive.ql.parse
Implementation of the Row Resolver.
RowResolver() - Constructor for class org.apache.hadoop.hive.ql.parse.RowResolver
 
RowSchema - Class in org.apache.hadoop.hive.ql.exec
RowSchema Implementation.
RowSchema() - Constructor for class org.apache.hadoop.hive.ql.exec.RowSchema
 
RowSchema(ArrayList<ColumnInfo>) - Constructor for class org.apache.hadoop.hive.ql.exec.RowSchema
 
rowSeparator - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
rowUpdated() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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(String[]) - Method in class org.apache.hadoop.hive.cli.RCFileCat
 
run() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
run() - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
This method scans the SessionItem collection.
run(String) - Method in class org.apache.hadoop.hive.ql.Driver
 
run() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
run() - Method in class org.apache.hadoop.hive.ql.exec.Utilities.StreamPrinter
 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.hooks.EnforceReadOnlyTables
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.EnforceReadOnlyTables
 
run(HookContext) - Method in interface org.apache.hadoop.hive.ql.hooks.ExecuteWithHookContext
 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.hooks.MapJoinCounterHook
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, LineageInfo, UserGroupInformation) - Method in interface org.apache.hadoop.hive.ql.hooks.PostExecute
Deprecated. 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, LineageInfo, UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.PostExecutePrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in interface org.apache.hadoop.hive.ql.hooks.PreExecute
Deprecated. 
run(HookContext) - Method in class org.apache.hadoop.hive.ql.hooks.PreExecutePrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.PreExecutePrinter
 
run(SessionState, Set<ReadEntity>, Set<WriteEntity>, UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.UpdateInputAccessTimeHook.PreExec
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.AddResourceProcessor
 
run(String) - Method in interface org.apache.hadoop.hive.ql.processors.CommandProcessor
 
run(String) - Method in class org.apache.hadoop.hive.ql.processors.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
 
run() - Method in class org.apache.hadoop.hive.ql.QTestUtil.QTRunner
 
runnable - Variable in class org.apache.hadoop.hive.hwi.HWISessionItem
 
runQuery() - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
runQuery iterates the list of queries executing each query.
runSequential() - Method in class org.apache.hadoop.hive.ql.exec.TaskRunner
Launches a task, and sets its exit value in the result variable.
runStatus - Variable in class org.apache.hadoop.hive.ql.exec.TaskResult
 

S

s - Variable in class org.apache.hadoop.hive.ql.io.JavaTestObjFlatFileInputFormat
 
Sample - Class in org.apache.hadoop.hive.ql.metadata
A sample defines a subset of data based on sampling on a given dimension.
Sample(int, int, Dimension) - Constructor for class org.apache.hadoop.hive.ql.metadata.Sample
 
sampleDimension - Variable in class org.apache.hadoop.hive.ql.metadata.Sample
 
sampleFraction - Variable in class org.apache.hadoop.hive.ql.metadata.Sample
 
sampleNum - Variable in class org.apache.hadoop.hive.ql.metadata.Sample
 
SamplePruner - Class in org.apache.hadoop.hive.ql.optimizer
The transformation step that does sample pruning.
SamplePruner() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner
 
SamplePruner.DefaultPPR - Class in org.apache.hadoop.hive.ql.optimizer
DefaultPPR default processor which does nothing.
SamplePruner.DefaultPPR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner.DefaultPPR
 
SamplePruner.FilterPPR - Class in org.apache.hadoop.hive.ql.optimizer
FilterPPR filter processor.
SamplePruner.FilterPPR() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner.FilterPPR
 
SamplePruner.SamplePrunerCtx - Class in org.apache.hadoop.hive.ql.optimizer
SamplePrunerCtx.
SamplePruner.SamplePrunerCtx(HashMap<TableScanOperator, FilterDesc.sampleDesc>) - Constructor for class org.apache.hadoop.hive.ql.optimizer.SamplePruner.SamplePrunerCtx
 
Schema - Class in org.apache.hadoop.hive.metastore.api
 
Schema() - Constructor for class org.apache.hadoop.hive.metastore.api.Schema
 
Schema(List<FieldSchema>, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.Schema
 
Schema(Schema) - Constructor for class org.apache.hadoop.hive.metastore.api.Schema
Performs a deep copy on other.
Schema._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SchemaDesc - Class in org.apache.hadoop.hive.ql.plan
SchemaDesc.
SchemaDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SchemaDesc
 
SchemaDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.SchemaDesc
 
ScriptDesc - Class in org.apache.hadoop.hive.ql.plan
ScriptDesc.
ScriptDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
ScriptDesc(String, TableDesc, Class<? extends RecordWriter>, TableDesc, Class<? extends RecordReader>, Class<? extends RecordReader>, TableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
ScriptErrorHeuristic - Class in org.apache.hadoop.hive.ql.exec.errors
Detects when a query has failed because a user's script that was specified in transform returns a non-zero error code.
ScriptErrorHeuristic() - Constructor for class org.apache.hadoop.hive.ql.exec.errors.ScriptErrorHeuristic
 
ScriptOperator - Class in org.apache.hadoop.hive.ql.exec
ScriptOperator.
ScriptOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.ScriptOperator
 
ScriptOperator.Counter - Enum in org.apache.hadoop.hive.ql.exec
Counter.
ScriptOperator.PathFinder - Class in org.apache.hadoop.hive.ql.exec
Maps a relative pathname to an absolute pathname using the PATH enviroment.
ScriptOperator.PathFinder(String) - Constructor for class org.apache.hadoop.hive.ql.exec.ScriptOperator.PathFinder
Construct a PathFinder object using the path from the specified system environment variable.
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.
SELECT - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
selectClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SelectDesc - Class in org.apache.hadoop.hive.ql.plan
SelectDesc.
SelectDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SelectDesc
 
SelectDesc(boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.SelectDesc
 
SelectDesc(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
 
selectStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
selectTrfmClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SemanticAnalyzer - Class in org.apache.hadoop.hive.ql.parse
Implementation of the semantic analyzer.
SemanticAnalyzer(HiveConf) - Constructor for class org.apache.hadoop.hive.ql.parse.SemanticAnalyzer
 
SemanticAnalyzerFactory - Class in org.apache.hadoop.hive.ql.parse
SemanticAnalyzerFactory.
SemanticException - Exception in org.apache.hadoop.hive.ql.parse
Exception from SemanticAnalyzer.
SemanticException() - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
SemanticException(String) - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
SemanticException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
SemanticException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.parse.SemanticException
 
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_index(Index, Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_add_partition(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_database(String, Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_index(String, String, String, Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_partition(String, String, Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_alter_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_append_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_cancel_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_database(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_role(Role) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_table(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_create_type(Type) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_database(String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_index_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_partition(String, String, List<String>, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_partition_by_name(String, String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_role(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_table(String, String, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_drop_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_all_databases() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_all_tables(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_config_value(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_database(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_databases(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_delegation_token_with_signature(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_fields(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_index_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_index_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_indexes(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition(String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_by_name(String, String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_names(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_names_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partition_with_auth(String, String, List<String>, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions(String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_by_filter(String, String, String, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_ps(String, String, List<String>, short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_ps_with_auth(String, String, List<String>, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_partitions_with_auth(String, String, short, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_privilege_set(HiveObjectRef, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_role_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_schema(String, String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_get_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_getQueryPlan() - 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
 
send_grant_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_grant_role(String, String, PrincipalType, String, PrincipalType, boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_list_privileges(String, PrincipalType, HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_list_roles(String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_partition_name_to_spec(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_partition_name_to_vals(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_renew_delegation_token(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_revoke_privileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
send_revoke_role(String, String, PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
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
 
SEQUENCEFILE_INPUT - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
SEQUENCEFILE_OUTPUT - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
SequenceFileInputFormatChecker - Class in org.apache.hadoop.hive.ql.io
SequenceFileInputFormatChecker.
SequenceFileInputFormatChecker() - Constructor for class org.apache.hadoop.hive.ql.io.SequenceFileInputFormatChecker
 
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
 
SerDeInfo - Class in org.apache.hadoop.hive.metastore.api
 
SerDeInfo() - Constructor for class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
SerDeInfo(String, String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
SerDeInfo(SerDeInfo) - Constructor for class org.apache.hadoop.hive.metastore.api.SerDeInfo
Performs a deep copy on other.
SerDeInfo._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SerDeUtils - Class in org.apache.hadoop.hive.serde2
SerDeUtils.
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
 
SERIALIZATION_USE_JSON_OBJECTS - 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.
SerializationSubclassKey - Static variable in class org.apache.hadoop.hive.ql.io.FlatFileInputFormat.SerializationContextFromConf
The JobConf keys for the Class that is being deserialized.
serialize(RecordOutput, String) - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
serialize() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
In preparation for a Hive merge() call, serializes the current n-gram estimator object into an ArrayList of Text objects.
serialize() - Method in class org.apache.hadoop.hive.ql.udf.generic.NumericHistogram
In preparation for a Hive merge() call, serializes the current histogram object into an ArrayList of DoubleWritable objects.
serialize(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.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(Object, ObjectInspector) - Method in class org.apache.hadoop.hive.serde2.TestSerDe
 
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
 
serializeExpression(ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
serializeField(ByteStream.Output, Object, ObjectInspector, LazySimpleSerDe.SerDeParameters) - Method in class org.apache.hadoop.hive.serde2.DelimitedJSONSerDe
 
serializeField(ByteStream.Output, Object, ObjectInspector, LazySimpleSerDe.SerDeParameters) - Method in class org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
 
serializeMapRedLocalWork(MapredLocalWork, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Serialize the mapredLocalWork object to an output stream.
serializeMapRedWork(MapredWork, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Serialize the mapredWork object to an output stream.
serializeQueryPlan(QueryPlan, OutputStream) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Serialize the whole query plan.
serializer - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
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
Serialize a single Task.
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.
SessionState() - Constructor for class org.apache.hadoop.hive.ql.session.SessionState
 
SessionState(HiveConf) - 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
ResourceHook.
SessionState.ResourceType - Enum in org.apache.hadoop.hive.ql.session
ResourceType.
set(String, Object) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
set(int) - Method in class org.apache.hadoop.hive.ql.exec.ByteWritable
 
set(String) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
set(int, BytesRefWritable) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Set the BytesRefWritable at the specified position with the specified BytesRefWritable.
set(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
readFields() will corrupt the array.
set(LazyDecompressionCallback, int, int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefWritable
readFields() will corrupt the array.
set(byte) - 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 class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaBooleanObjectInspector
 
set(Object, byte) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaByteObjectInspector
 
set(Object, double) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaDoubleObjectInspector
 
set(Object, float) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaFloatObjectInspector
 
set(Object, int) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaIntObjectInspector
 
set(Object, long) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaLongObjectInspector
 
set(Object, short) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaShortObjectInspector
 
set(Object, Text) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
set(Object, String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.JavaStringObjectInspector
 
set(Object, 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(Object, int, Object) - Method in interface org.apache.hadoop.hive.serde2.objectinspector.SettableListObjectInspector
Set the element at index.
set(Object, int, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardListObjectInspector
 
set_table_parameters(String, String, Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
setAbort(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapper
 
setAddPartitionDesc(AddPartitionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAddTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setAdjacencyList(List<Adjacency>) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setAdjacencyListIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setAdjacencyType(AdjacencyType) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setAdjacencyTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setAfterCol(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setAggKey(String) - Method in class org.apache.hadoop.hive.ql.plan.StatsWork
 
setAggregationExprsForClause(String, LinkedHashMap<String, ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setAggregators(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.ColumnInfo
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.exec.Operator
Store the alias this operator is working on behalf of.
setAlias(String) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setAliasBucketBaseFileNameMapping(LinkedHashMap<String, LinkedHashMap<String, ArrayList<String>>>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
setAliasBucketFileNameMapping(LinkedHashMap<String, LinkedHashMap<String, ArrayList<String>>>) - Method in interface org.apache.hadoop.hive.ql.exec.BucketMatcher
 
setAliasBucketFileNameMapping(LinkedHashMap<String, LinkedHashMap<String, ArrayList<String>>>) - Method in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
setAliasBucketFileNameMapping(LinkedHashMap<String, LinkedHashMap<String, ArrayList<String>>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setAliasBucketFileNameMapping(LinkedHashMap<String, LinkedHashMap<String, ArrayList<String>>>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setAliasBucketFileNameMapping(LinkedHashMap<String, LinkedHashMap<String, ArrayList<String>>>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
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
 
setAliasToPath(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setAliasToTask(HashMap<String, Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
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.
setAllUnionObjectTypeInfos(List<TypeInfo>) - Method in class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
For java serialization use only.
setAlterDatabaseDesc(AlterDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterIndexDesc(AlterIndexDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterTblDesc(AlterTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setAlterTblSimpleDesc(AlterTableSimpleDesc) - 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
 
setAttribute(Attribute) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
setAttributes(AttributeList) - Method in class org.apache.hadoop.hive.common.metrics.MetricsMBeanImpl
 
setAuth(HWIAuth) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
 
setAuthenticator(HiveAuthenticationProvider) - Method in interface org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProvider
 
setAuthenticator(HiveAuthenticationProvider) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
setAuthenticator(HiveAuthenticationProvider) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setAuthorizer(HiveAuthorizationProvider) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setAutoCommit(boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setAuxJars(String) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setBackupChildrenTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setBackupTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setBase_tbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setBase_tbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setBaseCols(List<LineageInfo.BaseColumnInfo>) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
setBaseFileName(String) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setBaseSrc(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setBaseTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
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
 
setBigKeysDirMap(Map<Byte, String>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setBigKeysDirMap(Map<Byte, String>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
set the mapping from tbl to dir for big keys.
setBigTableAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setBigTableAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
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
 
setBlockPointer(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
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
 
setBoolVar(Configuration, HiveConf.ConfVars, boolean) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setBoolVar(HiveConf.ConfVars, boolean) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
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(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setBucketColsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setBucketColumns(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setBucketFileNameMapping(LinkedHashMap<String, Integer>) - Method in interface org.apache.hadoop.hive.ql.exec.BucketMatcher
 
setBucketFileNameMapping(LinkedHashMap<String, Integer>) - Method in class org.apache.hadoop.hive.ql.exec.DefaultBucketMatcher
 
setBucketFileNameMapping(LinkedHashMap<String, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setBucketFileNameMapping(LinkedHashMap<String, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setBucketFileNameMapping(LinkedHashMap<String, Integer>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
setBucketGroup(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setBucketMapjoinContext(MapredLocalWork.BucketMapJoinContext) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setBucketMatcherClass(Class<? extends BucketMatcher>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
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.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
 
setChildren(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setChildrenIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setChildTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setClassName(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setClassName(String) - Method in class org.apache.hadoop.hive.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
 
setColIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setCollector(Collector) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTF
Associates a collector with this UDTF.
setColList(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.SelectDesc
 
setCollItemDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setCollItemDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
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(ArrayList<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setColsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setColumn(FieldSchema) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
setColumn(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
setColumnDesc(ExprNodeColumnDesc) - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
setColumnExprMap(Map<String, ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setColumnName(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setColumnName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setColumnName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setColumnNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setColumnNameList(JobConf, Operator) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
setColumnNumber(Configuration, int) - Static method in class org.apache.hadoop.hive.ql.io.RCFileOutputFormat
set number of columns into the given configuration.
setColumns(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
setColumns(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
setColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
setColumnTypes(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadFileDesc
 
setColumnTypes(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setCommand(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setCommandType(HiveOperation) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setComment(String) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setComment(String) - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
setComment(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setComment(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setComment(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setComment(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setCommentIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setComments(String) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setCommentsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setCommonJoinTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx
 
setComparisonExpr(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
setComparisonOp(String) - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
setComplete(boolean) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
setCompleteTaskList(List<TaskRunner>) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setCompressCodec(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setCompressed(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setCompressed(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setCompressed(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setCompressedIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setCompressType(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setConds(JoinCondDesc[]) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setConds(JoinCondDesc[]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.cli.RCFileCat
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.HiveAlterHandler
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.metastore.ObjectStore
Called whenever this object is instantiated using ReflectionUils, and also on connection retries.
setConf(T) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
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.lockmgr.HiveLockManagerCtx
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.parse.HiveSemanticAnalyzerHookContextImpl
 
setConf(HiveConf) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.security.authorization.HiveAuthorizationProviderBase
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.security.DummyAuthenticator
 
setConf(Configuration) - Method in class org.apache.hadoop.hive.ql.security.HadoopDefaultAuthenticator
 
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.
setConsole(SessionState.LogHelper) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
setConstantDesc(ExprNodeConstantDesc) - Method in class org.apache.hadoop.hive.ql.index.IndexSearchCondition
 
setContext(HiveLockManagerCtx) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
setContext(HiveLockManagerCtx) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
setContext(Context) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
setContext(Context) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setCounterNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setCounterNameToEnum(HashMap<String, Operator.ProgressCounter>) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setCounters(HashMap<String, HashMap<String, Long>>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setCreateDatabaseDesc(CreateDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
Set Create Database descriptor
setCreateFunctionDesc(CreateFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
setCreateIndexDesc(CreateIndexDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCreateTableGrants(CreateTableAutomaticGrant) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setCreateTblDesc(CreateTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCreateTblLikeDesc(CreateTableLikeDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setCreateTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setCreateTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setCreateViewDesc(CreateViewDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCreateVwDesc(CreateViewDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setCurrAliasId(String) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrentBigBucketFile(String) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
setCurrentBlockStart(long) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setCurrentDatabase(String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
Set the name of the current database
setCurrentInputFile(String) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
setCurrentMemory(long) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
setCurrentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setCurrentTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
setCurrMapJoinOp(AbstractMapJoinOperator<? extends MapJoinDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrMapJoinOp(AbstractMapJoinOperator<? extends MapJoinDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setCurrPart(PartitionDesc) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setCurrTask(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setCurrTbl(TableDesc) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setCurrTopOp(Operator<? extends 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
 
setD(String) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
setData(HiveLockObject.HiveLockObjectData) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject
 
setData(byte[]) - Method in class org.apache.hadoop.hive.serde2.lazy.ByteArrayRef
 
setDatabase(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
setDatabase(MDatabase) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setDatabase(MDatabase) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setDatabaseIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
setDatabaseName(String) - Method in class org.apache.hadoop.hive.ql.plan.SwitchDatabaseDesc
 
setDatabaseProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setDatabaseProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setDataLocation(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(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setDb_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setDb_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setDbIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setDbName(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
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_database_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setDbname(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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.index.compact.IndexMetadataChangeWork
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
setDbName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setDbNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setDbnameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setDebugStream(PrintStream) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Set debug output.
setDefaultPartitionName(String) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setDefaultValue(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setDefaultValueIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setDeferredRebuild(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setDeferredRebuild(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setDeferredRebuild(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setDeferredRebuildIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setDeleteData(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setDeleteDataIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_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
 
setDescFunctionDesc(DescFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDescription(String) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setDescription(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setDescriptionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setDescTblDesc(DescTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDeserializerClass(Class<? extends Deserializer>) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
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
 
setDirToTaskMap(HashMap<String, Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx
 
setDistinct(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setDistinctColumnIndices(List<List<Integer>>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setDistinctFuncExprsForClause(String, List<ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setDistributeByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
Set the Distribute By AST for the clause.
setDone(boolean) - Static method in class org.apache.hadoop.hive.ql.exec.ExecMapper
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setDone() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setDone(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setDone() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setDone(HashSet<String>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setDoneIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
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
 
setDPColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setDPCtx(String, DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
setDPCtx(DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
setDPCtx(DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setDPSpecPaths(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setDropDatabaseDesc(DropDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
Set Drop Database descriptor
setDropFunctionDesc(DropFunctionDesc) - Method in class org.apache.hadoop.hive.ql.plan.FunctionWork
 
setDropIdxDesc(DropIndexDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDropTblDesc(DropTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setDummyParentOp(List<Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setDummyParentOp(List<Operator<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setDumpFile(File) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
setDynPartCtx(DynamicPartitionCtx) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setEmptyTable(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setError(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setErrorCode(int) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setErrorCodeIsSet(boolean) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setErrorFile(String) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
Currently unused.
setErrRecordReaderClass(Class<? extends RecordReader>) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
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.getQueryPlan_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setEx(HiveServerException) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setExcludeQueryFile(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setExecContext(ExecMapperContext) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setExIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setExitVal(int) - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
setExpectView(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setExpectView(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setExplain(boolean) - Method in class org.apache.hadoop.hive.ql.Context
Set the context on whether the current query is an explain query.
setExpr(String) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
setExpressionMap(Map<String, ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setExpressions(ArrayList<ArrayList<ASTNode>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setExprResolver(boolean) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setExprs(ArrayList<ASTNode>) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the expression list.
setExprs(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setExprs(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setExprToColumnAlias(ASTNode, String) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setExt(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
setExt(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setExt(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setExtended(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
setExtended(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setExternal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setExternal(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setFeedSubscribers(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setFetchDirection(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.HiveStatement
 
setFetchOperators(Map<String, FetchOperator>) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
setFetchSize(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.HiveStatement
 
setFetchTask(FetchTask) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
setFetchTask(FetchTask) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setField0(int) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
setField0IsSet(boolean) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
setField1(int) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField1IsSet(boolean) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField2(String) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField2IsSet(boolean) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField3(List<InnerStruct>) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setField3IsSet(boolean) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setFieldDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setFieldDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setFieldEscape(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setFieldEscape(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setFieldInited(boolean[]) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
setFieldName(String) - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
setFieldName(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
setFields(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setFields(List<MFieldSchema>) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setFields(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setFields(LazyObject[]) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
setFieldSchemas(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setFieldSchemasIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setFieldsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setFieldValue(AlreadyExistsException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
setFieldValue(ConfigValSecurityException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
setFieldValue(Database._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setFieldValue(FieldSchema._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setFieldValue(HiveObjectPrivilege._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setFieldValue(HiveObjectRef._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setFieldValue(Index._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setFieldValue(IndexAlreadyExistsException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
setFieldValue(InvalidObjectException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
setFieldValue(InvalidOperationException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
setFieldValue(MetaException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
setFieldValue(NoSuchObjectException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
setFieldValue(Order._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setFieldValue(Partition._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setFieldValue(PrincipalPrivilegeSet._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setFieldValue(PrivilegeBag._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
setFieldValue(PrivilegeGrantInfo._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setFieldValue(Role._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setFieldValue(Schema._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setFieldValue(SerDeInfo._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setFieldValue(StorageDescriptor._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setFieldValue(Table._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setFieldValue(ThriftHiveMetastore.add_index_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setFieldValue(ThriftHiveMetastore.add_index_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setFieldValue(ThriftHiveMetastore.add_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
setFieldValue(ThriftHiveMetastore.add_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setFieldValue(ThriftHiveMetastore.alter_database_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
setFieldValue(ThriftHiveMetastore.alter_database_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setFieldValue(ThriftHiveMetastore.alter_index_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setFieldValue(ThriftHiveMetastore.alter_index_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setFieldValue(ThriftHiveMetastore.alter_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setFieldValue(ThriftHiveMetastore.alter_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setFieldValue(ThriftHiveMetastore.alter_table_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setFieldValue(ThriftHiveMetastore.alter_table_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setFieldValue(ThriftHiveMetastore.append_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setFieldValue(ThriftHiveMetastore.append_partition_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setFieldValue(ThriftHiveMetastore.append_partition_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setFieldValue(ThriftHiveMetastore.append_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setFieldValue(ThriftHiveMetastore.cancel_delegation_token_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
setFieldValue(ThriftHiveMetastore.cancel_delegation_token_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
setFieldValue(ThriftHiveMetastore.create_database_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
setFieldValue(ThriftHiveMetastore.create_database_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setFieldValue(ThriftHiveMetastore.create_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
setFieldValue(ThriftHiveMetastore.create_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setFieldValue(ThriftHiveMetastore.create_table_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
setFieldValue(ThriftHiveMetastore.create_table_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setFieldValue(ThriftHiveMetastore.create_type_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
setFieldValue(ThriftHiveMetastore.create_type_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setFieldValue(ThriftHiveMetastore.drop_database_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setFieldValue(ThriftHiveMetastore.drop_database_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setFieldValue(ThriftHiveMetastore.drop_index_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setFieldValue(ThriftHiveMetastore.drop_index_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setFieldValue(ThriftHiveMetastore.drop_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setFieldValue(ThriftHiveMetastore.drop_partition_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setFieldValue(ThriftHiveMetastore.drop_partition_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setFieldValue(ThriftHiveMetastore.drop_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setFieldValue(ThriftHiveMetastore.drop_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
setFieldValue(ThriftHiveMetastore.drop_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setFieldValue(ThriftHiveMetastore.drop_table_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setFieldValue(ThriftHiveMetastore.drop_table_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setFieldValue(ThriftHiveMetastore.drop_type_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
setFieldValue(ThriftHiveMetastore.drop_type_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setFieldValue(ThriftHiveMetastore.get_all_databases_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
setFieldValue(ThriftHiveMetastore.get_all_databases_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setFieldValue(ThriftHiveMetastore.get_all_tables_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
setFieldValue(ThriftHiveMetastore.get_all_tables_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setFieldValue(ThriftHiveMetastore.get_config_value_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setFieldValue(ThriftHiveMetastore.get_config_value_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setFieldValue(ThriftHiveMetastore.get_database_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
setFieldValue(ThriftHiveMetastore.get_database_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setFieldValue(ThriftHiveMetastore.get_databases_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
setFieldValue(ThriftHiveMetastore.get_databases_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setFieldValue(ThriftHiveMetastore.get_delegation_token_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
setFieldValue(ThriftHiveMetastore.get_delegation_token_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setFieldValue(ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
setFieldValue(ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
setFieldValue(ThriftHiveMetastore.get_fields_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setFieldValue(ThriftHiveMetastore.get_fields_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setFieldValue(ThriftHiveMetastore.get_index_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setFieldValue(ThriftHiveMetastore.get_index_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setFieldValue(ThriftHiveMetastore.get_index_names_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setFieldValue(ThriftHiveMetastore.get_index_names_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setFieldValue(ThriftHiveMetastore.get_indexes_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setFieldValue(ThriftHiveMetastore.get_indexes_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setFieldValue(ThriftHiveMetastore.get_partition_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setFieldValue(ThriftHiveMetastore.get_partition_by_name_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setFieldValue(ThriftHiveMetastore.get_partition_by_name_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setFieldValue(ThriftHiveMetastore.get_partition_names_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setFieldValue(ThriftHiveMetastore.get_partition_names_ps_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setFieldValue(ThriftHiveMetastore.get_partition_names_ps_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setFieldValue(ThriftHiveMetastore.get_partition_names_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setFieldValue(ThriftHiveMetastore.get_partition_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setFieldValue(ThriftHiveMetastore.get_partition_with_auth_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setFieldValue(ThriftHiveMetastore.get_partition_with_auth_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_by_filter_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_by_filter_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_ps_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_ps_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setFieldValue(ThriftHiveMetastore.get_partitions_with_auth_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setFieldValue(ThriftHiveMetastore.get_partitions_with_auth_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setFieldValue(ThriftHiveMetastore.get_privilege_set_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setFieldValue(ThriftHiveMetastore.get_privilege_set_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setFieldValue(ThriftHiveMetastore.get_role_names_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
setFieldValue(ThriftHiveMetastore.get_role_names_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setFieldValue(ThriftHiveMetastore.get_schema_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setFieldValue(ThriftHiveMetastore.get_schema_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setFieldValue(ThriftHiveMetastore.get_table_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setFieldValue(ThriftHiveMetastore.get_table_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setFieldValue(ThriftHiveMetastore.get_tables_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setFieldValue(ThriftHiveMetastore.get_tables_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setFieldValue(ThriftHiveMetastore.get_type_all_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
setFieldValue(ThriftHiveMetastore.get_type_all_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setFieldValue(ThriftHiveMetastore.get_type_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
setFieldValue(ThriftHiveMetastore.get_type_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setFieldValue(ThriftHiveMetastore.grant_privileges_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
setFieldValue(ThriftHiveMetastore.grant_privileges_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setFieldValue(ThriftHiveMetastore.grant_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setFieldValue(ThriftHiveMetastore.grant_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setFieldValue(ThriftHiveMetastore.list_privileges_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setFieldValue(ThriftHiveMetastore.list_privileges_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setFieldValue(ThriftHiveMetastore.list_roles_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setFieldValue(ThriftHiveMetastore.list_roles_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setFieldValue(ThriftHiveMetastore.partition_name_to_spec_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
setFieldValue(ThriftHiveMetastore.partition_name_to_spec_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setFieldValue(ThriftHiveMetastore.partition_name_to_vals_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
setFieldValue(ThriftHiveMetastore.partition_name_to_vals_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setFieldValue(ThriftHiveMetastore.renew_delegation_token_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
setFieldValue(ThriftHiveMetastore.renew_delegation_token_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setFieldValue(ThriftHiveMetastore.revoke_privileges_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
setFieldValue(ThriftHiveMetastore.revoke_privileges_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setFieldValue(ThriftHiveMetastore.revoke_role_args._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setFieldValue(ThriftHiveMetastore.revoke_role_result._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setFieldValue(Type._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setFieldValue(UnknownDBException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
setFieldValue(UnknownTableException._Fields, Object) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
setFieldValue(Version._Fields, Object) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setFieldValue(Adjacency._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setFieldValue(Graph._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setFieldValue(Operator._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setFieldValue(Query._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setFieldValue(QueryPlan._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setFieldValue(Stage._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setFieldValue(Task._Fields, Object) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setFieldValue(InnerStruct._Fields, Object) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
setFieldValue(ThriftTestObj._Fields, Object) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
setFieldValue(Complex._Fields, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setFieldValue(IntString._Fields, Object) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setFieldValue(HiveClusterStatus._Fields, Object) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setFieldValue(HiveServerException._Fields, Object) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setFieldValue(ThriftHive.execute_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
setFieldValue(ThriftHive.execute_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
setFieldValue(ThriftHive.fetchAll_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
setFieldValue(ThriftHive.fetchAll_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setFieldValue(ThriftHive.fetchN_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
setFieldValue(ThriftHive.fetchN_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setFieldValue(ThriftHive.fetchOne_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
setFieldValue(ThriftHive.fetchOne_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setFieldValue(ThriftHive.getClusterStatus_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
setFieldValue(ThriftHive.getClusterStatus_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setFieldValue(ThriftHive.getQueryPlan_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
setFieldValue(ThriftHive.getQueryPlan_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setFieldValue(ThriftHive.getSchema_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
setFieldValue(ThriftHive.getSchema_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setFieldValue(ThriftHive.getThriftSchema_args._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
setFieldValue(ThriftHive.getThriftSchema_result._Fields, Object) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setFile(String) - Method in class org.apache.hadoop.hive.ql.log.PidDailyRollingFileAppender
 
setFileId(Integer) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
setFilter(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setFilterExpr(ExprNodeDesc) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setFilterIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setFilters(ArrayList<ArrayList<ASTNode>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setFilters(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setFilters(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setFiltersForPushing(ArrayList<ArrayList<ASTNode>>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setFirst(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
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
 
setFloatConf(Configuration, String, float) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Wrapper for Configuration.setFloat, which was not introduced until 0.20.
setFloatVar(Configuration, HiveConf.ConfVars, float) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setFloatVar(HiveConf.ConfVars, float) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setFollowedByGroupBy(boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setFormatted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setFormatted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
setFromPath(String) - Method in class org.apache.hadoop.hive.ql.plan.CopyWork
 
setFullyReadColumns(Configuration) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
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
 
setGatheringStats(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setGatherStats(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setGatherStats(boolean) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setGenericUDAFEvaluator(GenericUDAFEvaluator) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setGenericUDAFName(String) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setGenericUDF(GenericUDF) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
setGenericUDTF(GenericUDTF) - Method in class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
setGoOn(boolean) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
setGrant(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrant_option(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrant_optionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantDesc(GrantDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setGrantInfo(PrivilegeGrantInfo) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setGrantInfoIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setGrantOption(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrantOptionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setGrantor(String) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setGrantor(String) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrantorIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantorIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setGrantorType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setGrantorType(PrincipalType) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setGrantorTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setGrantorTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setGrantRevokeRoleDDL(GrantRevokeRoleDDL) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setGroup(boolean) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setGroup_names(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setGroup_namesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setGroupByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setGroupByMemoryUsage(float) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setGroupKeyNotReductionKey(boolean) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setGroupKeyObject(Object) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setGroupOpToInputTables(Map<GroupByOperator, Set<String>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setGroupPrivileges(Map<String, List<PrivilegeGrantInfo>>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setGroupPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setGroups(String[]) - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
setHadoopSupportsSplittable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setHadoopVersion(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setHandleSkewJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setHandleSkewJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
set to handle skew join in this join op.
setHashCode(int) - Method in class org.apache.hadoop.hive.ql.io.HiveKey
 
setHashtableMemoryUsage(float) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
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.
setHavingExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setHiddenVirtualCol(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setHints(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setHiveLockMgr(HiveLockManager) - Method in class org.apache.hadoop.hive.ql.Context
 
setHiveLockMode(HiveLockMode) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
setHiveLockObject(HiveLockObject) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
setHiveLocks(List<HiveLock>) - Method in class org.apache.hadoop.hive.ql.Context
 
setHiveObj(PrivilegeObjectDesc) - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
setHiveObject(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setHiveObject(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setHiveObject(HiveObjectRef) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setHiveObjectIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setHiveObjectIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setHiveObjectIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setHoldability(int) - Method in class org.apache.hadoop.hive.jdbc.HiveConnection
 
setHoldDDLTime(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
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
 
setIdToTableNameMap(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setIdx_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setIdx_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setIdxProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIfExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.DropDatabaseDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setIfNotExists(boolean) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setImplementation(String, Configuration) - Static method in class org.apache.hadoop.hive.ql.stats.StatsFactory
Sets the paths of the implementation classes of publishing and aggregation (IStatsPublisher and IStatsAggregator interfaces).
setIndex(LineageCtx.Index) - Method in class org.apache.hadoop.hive.ql.session.LineageState
Sets the index for the lineage state.
setIndex_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setIndex_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setIndex_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setIndex_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setIndex_table(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setIndex_tableIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setIndexComment(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexedCols(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexHandlerClass(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexHandlerClass(String) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setIndexHandlerClassIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexName(String) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setIndexName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setIndexName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
setIndexNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setIndexTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setIndexTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setIndexTbl(String) - Method in class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeWork
 
setIndexTypeHandlerClass(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setInitialized() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setInput(String) - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
setInputFile(String) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setInputFileChangeSensitive(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setInputFileFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setInputFileFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setInputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setInputformat(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setInputFormatClass(Class<? extends InputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setInputFormatClass(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setInputFormatClassName(String) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
setInputFormatClassName(String) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
 
setInputFormatIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setInputObjInspectors(ObjectInspector[]) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setInputPruning(boolean) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the flag that indicates whether input pruning is possible or not.
setInputRR(RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
setInputs(Set<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setInputs(HashSet<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setInputs(HashSet<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setInputs(HashSet<ReadEntity>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setInputToDPCols(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setInRecordWriterClass(Class<? extends RecordWriter>) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setInspector(OI) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyObject
 
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
 
setIntVar(Configuration, HiveConf.ConfVars, int) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setIntVar(HiveConf.ConfVars, int) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
setInvRslvMap(HashMap<String, String[]>) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setIoCxt(IOContext) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
setIOExceptions(boolean) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setIsAnalyzeCommand(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
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
 
setIsDfsDir(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setIsExprResolver(boolean) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setIsHidden(boolean) - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
setIsInsertToTable(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setIsList(Boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
setIsPartitionColOrVirtualCol(boolean) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
setIsQuery(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setIsSamplingPred(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
setIsSilent(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setIsVerbose(boolean) - Method in class org.apache.hadoop.hive.ql.session.SessionState
 
setItems(TreeMap<HWIAuth, Set<HWISessionItem>>) - Method in class org.apache.hadoop.hive.hwi.HWISessionManager
 
setJc(JobConf) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
setJobId(String) - Method in class org.apache.hadoop.hive.ql.exec.ExecDriver
 
setJobProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setJoinCond(JoinCond[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setJoinContext(Map<JoinOperator, QBJoinTree>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setJoinExpr(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setJoinSrc(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setJoinTree(QBJoinTree) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setJoinType(JoinType) - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
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
 
setKeyObject(List<Object>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setKeys(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setKeys(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setKeys(Map<Byte, List<ExprNodeDesc>>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setKeySerializeInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setKeyTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setKeyTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setKeyTblDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setKeyTblDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setLastAccessTime(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setLastAccessTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setLastAccessTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setLastAccessTimeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setLastInputFile(String) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
setLeft(int) - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
setLeft(int) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setLeftAlias(String) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
set left alias for the join expression.
setLeftAliases(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setLikeTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setLimit(int) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setLimit(int) - Method in class org.apache.hadoop.hive.ql.plan.LimitDesc
 
setLineage(String, LineageInfo.DataContainer, List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.session.LineageState
Set the lineage information for the associated directory.
setLineageInfo(LineageInfo) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Sets the lineage information.
setLineageInfo(LineageInfo) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
Sets the lineage information.
setLineageInfo(LineageInfo) - Method in class org.apache.hadoop.hive.ql.QueryPlan
Sets the lineage information.
setLineDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setLineDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setLinfo(LineageInfo) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setLint(List<Integer>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setLintIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setLintString(List<IntString>) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setLintStringIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
setList(List<Row>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
 
setListElementTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.ListTypeInfo
For java serialization use only.
setListMapJoinOpsNoReducer(List<AbstractMapJoinOperator<? extends MapJoinDesc>>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setListMapJoins(List<AbstractMapJoinOperator<? extends MapJoinDesc>>) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setListRejectedMapJoins(List<AbstractMapJoinOperator<? extends MapJoinDesc>>) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
setListTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.exec.ConditionalTask
 
setListTasks(List<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx
 
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
 
setLocalMode(boolean) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setLocalWork(MapredLocalWork) - Method in class org.apache.hadoop.hive.ql.exec.ExecMapperContext
 
setLocalWork(MapredLocalWork) - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setLocation(String) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setLocationIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setLocationUri(String) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setLocationUri(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setLocationUri(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterDatabaseDesc
 
setLocationUri(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setLocationUriIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setLockTblDesc(LockTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setLOG(Log) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
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
 
setLongVar(Configuration, HiveConf.ConfVars, long) - Static method in class org.apache.hadoop.hive.conf.HiveConf
 
setLongVar(HiveConf.ConfVars, long) - Method in class org.apache.hadoop.hive.conf.HiveConf
 
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
 
setMapJoinBigTableAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
setMapJoinContext(Map<MapJoinOperator, QBJoinTree>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setMapJoinCtx(AbstractMapJoinOperator<? extends MapJoinDesc>, GenMRProcContext.GenMRMapJoinCtx) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setMapJoinSubq(int, boolean) - Method in class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
setMapKeyDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setMapKeyDelim(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setMapKeyTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
For java serialization use only.
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
 
setMapperCannotSpanPartns(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setMapRedWork(Configuration, MapredWork, String) - 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
 
setMapTasksIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMapValueTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.serde2.typeinfo.MapTypeInfo
For java serialization use only.
setMax_indexes(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setMax_indexes(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setMax_indexesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setMax_indexesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setMax_parts(short) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setMax_partsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_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
 
setMaxMapTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxMapTasksIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxMemory(long) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
setMaxPartitionsPerNode(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setMaxReduceTasks(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxReduceTasksIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setMaxRows(int) - Method in class org.apache.hadoop.hive.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.
setMemoryMXBean(MemoryMXBean) - Static method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
setMemoryThreshold(float) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
setMessage(String) - Method in exception org.apache.hadoop.hive.metastore.api.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
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidObjectException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.InvalidOperationException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.MetaException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.NoSuchObjectException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setMetadataTag(int) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
setMHash(HashMap<K, V>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
setMinSplitSize(Long) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setMode(HiveLockMode) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
setMode(GenericUDAFEvaluator.Mode) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setMode(GroupByDesc.Mode) - Method in class org.apache.hadoop.hive.ql.plan.GroupByDesc
 
setMode(String) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setMode(short) - Method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
 
setMsckDesc(MsckDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
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
 
setMultiFilesDesc(LoadMultiFilesDesc) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setMultiFileSpray(boolean) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setMvTask(List<Task<? 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.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_config_value_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MFieldSchema
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
setName(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setName(String) - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
setName(String) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
setName(String) - Method in class org.apache.hadoop.hive.ql.metadata.DummyPartition
 
setName(String) - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateDatabaseDesc
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
setName(String) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
setNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
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
 
setNeedLockMgr(boolean) - Method in class org.apache.hadoop.hive.ql.Context
 
setNeedsTagging(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setNew_idx(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setNew_idxIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
setNew_index(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setNew_indexIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
setNew_part(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
setNew_part(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setNew_partIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
setNew_partIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setNew_tbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setNew_tblIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setNewColComment(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewColName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewCols(ArrayList<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewColType(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewLocation(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNewName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setNext(DCLLItem) - Method in class org.apache.hadoop.hive.ql.exec.persistence.DCLLItem
Set the next item as itm.
setNextBlockStart(long) - Method in class org.apache.hadoop.hive.ql.io.IOContext
 
setNode(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setNodeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
setNodeType(NodeType) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setNodeTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setNoOuterJoin(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setNoOuterJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setNoOuterJoin(boolean) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setNoSemiJoin(boolean) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
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
 
setNullOutputFormat(JobConf) - Method in interface org.apache.hadoop.hive.shims.HadoopShims
Hive uses side effect files exclusively for it's output.
setNum(NumberFormat) - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
setNum(long) - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
setNumberBuckets(int) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
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
 
setNumBuckets(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setNumBucketsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setNumDistributionKeys(int) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setNumDPCols(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setNumerator(int) - Method in class org.apache.hadoop.hive.ql.parse.TableSample
Sets the numerator.
setNumFiles(int) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
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
 
setNumMapTasks(Integer) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
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
 
setNumRowsIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
setNumSPCols(int) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setO1(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO1(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
setO1(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setO1(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO1(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setO1(ConfigValSecurityException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO1(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setO1(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setO1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO2(AlreadyExistsException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO2(InvalidObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO2(InvalidOperationException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setO2(NoSuchObjectException) - 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(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setO2(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO2(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setO2(UnknownTableException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO2(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(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setO2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO3(MetaException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_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_database_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_database_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
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setO3IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setO4(NoSuchObjectException) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setO4IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
setObj(Object[]) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
setObj(MapJoinRowContainer<Object[]>) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
setObj(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
setObj(HiveLockObject) - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObj
 
setObj1(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
setObj2(Object) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
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
 
setObject(String) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
setObject(Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
setObjectName(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setObjectNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setObjectType(HiveObjectType) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setObjectTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setOldColName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setOldMapJoin(AbstractMapJoinOperator<? extends MapJoinDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
setOldName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setOp(AlterIndexDesc.AlterIndexTypes) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setOp(AlterTableDesc.AlterTableTypes) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setOpcode(QBExpr.Opcode) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
setOperation(RoleDDLDesc.RoleOperation) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setOperator(boolean) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
setOperatorAttributes(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorCounters(Map<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorCountersIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorGraph(Graph) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setOperatorGraphIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setOperatorId(String) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setOperatorId(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorIdIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorList(List<Operator>) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setOperatorListIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setOperatorType(OperatorType) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOperatorTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setOpParseCtx(LinkedHashMap<Operator<? extends Serializable>, OpParseContext>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpParseCtxMap(LinkedHashMap<Operator<? extends Serializable>, OpParseContext>) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setOpTaskMap(HashMap<Operator<? extends Serializable>, Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setOpToPartList(HashMap<TableScanOperator, PrunedPartitionList>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpToPartPruner(HashMap<TableScanOperator, ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOpToSamplePruner(HashMap<TableScanOperator, FilterDesc.sampleDesc>) - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner.SamplePrunerCtx
 
setOpToSamplePruner(HashMap<TableScanOperator, FilterDesc.sampleDesc>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setOrder(int) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setOrder(int) - Method in class org.apache.hadoop.hive.metastore.model.MOrder
 
setOrder(String) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setOrderByExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setOrderIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Order
 
setOrigin(ASTNodeOrigin) - Method in class org.apache.hadoop.hive.ql.parse.ASTNode
Tag this ASTNode with information about the object from which this node originated.
setOriginalTracker(String) - Method in class org.apache.hadoop.hive.ql.Context
 
setOrigTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setOrigTableName(String) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setOrigTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
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(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setOutputColumnNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setOutputColumnNames(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.PartitionDesc
 
setOutputFileFormatClass(Class<?>) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setOutputFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setOutputFormatClass(Class<? extends HiveOutputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setOutputFormatClass(Class<? extends HiveOutputFormat>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOutputFormatClass(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setOutputFormatIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setOutputInternalColNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.LateralViewJoinDesc
 
setOutputKeyColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setOutputs(Set<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setOutputs(HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setOutputs(HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.plan.MoveWork
 
setOutputs(HashSet<WriteEntity>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setOutputValueColumnNames(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setOutRecordReaderClass(Class<? extends RecordReader>) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setOutWriters(FileSinkOperator.RecordWriter[]) - Method in class org.apache.hadoop.hive.ql.exec.FileSinkOperator.FSPaths
 
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
 
setOwnerIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setOwnerName(String) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setOwnerName(String) - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
setOwnerNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setP(Partition) - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
setP(Partition) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MDatabase
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MSerDeInfo
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MStorageDescriptor
 
setParameters(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setParameters(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.AggregationDesc
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setParametersIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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
 
setParseContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext
 
setParseCtx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext
 
setParseCtx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.MapJoinResolver.LocalMapJoinProcCtx
 
setParseCtx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
setParsed(boolean) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyMap
 
setParsed(boolean) - Method in class org.apache.hadoop.hive.serde2.lazy.LazyStruct
 
setParseTree(ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
setPart_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
setPart_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setPart_vals(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setPart_valsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setPartCols(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setPartCols(ArrayList<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setPartColumns(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setPartDesc(ArrayList<PartitionDesc>) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setPartDir(ArrayList<String>) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setPartition(MPartition) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setPartition(MPartition) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setPartitionCols(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setPartitionCols(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setPartitionDescMap(Map<Map<String, PartitionDesc>, Map<String, PartitionDesc>>) - Method in class org.apache.hadoop.hive.ql.io.IOPrepareCache
 
setPartitionKeys(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setPartitionKeys(List<MFieldSchema>) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setPartitionKeysIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setPartitionName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setPartitionName(String) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
setPartitionsNotInMs(List<CheckResult.PartitionResult>) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
setPartitionsNotOnFs(List<CheckResult.PartitionResult>) - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult
 
setPartitionSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setPartList(List<Partition>) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.index.compact.IndexMetadataChangeWork
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
setPartSpec(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setPartSpec(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setPartSpec(LinkedHashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
setPartSpec(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
setPartSpec(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
setPartSpecForAlias(String, Map<String, String>) - Method in class org.apache.hadoop.hive.ql.parse.QBMetaData
 
setPartSpecs(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setPartSpecs(ArrayList<LinkedHashMap<String, String>>) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setPartSpecs(ArrayList<LinkedHashMap<String, String>>) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setPartSpecs(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setPartValues(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setPartValuesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
setPath(String) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
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_databases_args
 
setPattern(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
setPattern(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
setPatternIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
setPatternIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
setPctx(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.Optimizer
 
setpGraphContext(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.MapJoinProcessor.MapJoinWalkerCtx
 
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.HashTableSinkDesc
 
setPosBigTable(int) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setPosition(int) - Method in class org.apache.hadoop.hive.ql.plan.ExplosionDesc
 
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
 
setPreserved(boolean) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setPrev(DCLLItem) - Method in class org.apache.hadoop.hive.ql.exec.persistence.DCLLItem
Set the previous item as itm.
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setPrincipal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setPrincipal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setPrincipal_type(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
setPrincipal_typeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setPrincipalDesc(List<PrincipalDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
setPrincipalDesc(PrincipalDesc) - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setPrincipalName(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setPrincipalNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setPrincipals(List<PrincipalDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setPrincipals(List<PrincipalDesc>) - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
setPrincipalType(PrincipalType) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setPrincipalType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setPrincipalType(PrincipalType) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setPrincipalTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
setPriv(Privilege.PrivilegeType) - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MDBPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MGlobalPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionColumnPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MPartitionPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setPrivilege(String) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setPrivilege(Privilege) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeDesc
 
setPrivilegeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
setPrivileges(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setPrivileges(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setPrivileges(List<HiveObjectPrivilege>) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
setPrivileges(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
setPrivileges(PrivilegeBag) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
setPrivileges(List<PrivilegeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setPrivileges(List<PrivilegeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Database
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
setPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
setPrivilegeSubjectDesc(PrivilegeObjectDesc) - Method in class org.apache.hadoop.hive.ql.plan.GrantDesc
 
setPrivilegeSubjectDesc(PrivilegeObjectDesc) - Method in class org.apache.hadoop.hive.ql.plan.RevokeDesc
 
SetProcessor - Class in org.apache.hadoop.hive.ql.processors
SetProcessor.
SetProcessor() - Constructor for class org.apache.hadoop.hive.ql.processors.SetProcessor
 
setProperties(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setProperties(Properties) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
setProperties(Properties) - Method in class org.apache.hadoop.hive.ql.plan.TableDesc
 
setPropertiesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
setProperty(String) - Method in class org.apache.hadoop.hive.ant.GetVersionPref
 
setProperty(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setProps(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterIndexDesc
 
setProps(HashMap<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setProtectMode(ProtectMode) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
setProtectMode(ProtectMode) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setProtectModeEnable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setProtectModeType(AlterTableDesc.ProtectModeType) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setPrunedPartitions(Map<String, PrunedPartitionList>) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setQB(QB) - Method in class org.apache.hadoop.hive.ql.parse.ParseContext
 
setQB(QB) - Method in class org.apache.hadoop.hive.ql.parse.QBExpr
 
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
 
setQueries(List<Query>) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setQueriesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setQuery(Query) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setQuery(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
setQueryAttributes(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryCounters(Map<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryCountersIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryDirectory(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setQueryFile(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setQueryFileRegex(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setQueryId(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryId(String) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setQueryId(String) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setQueryIdIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
setQueryPlan(QueryPlan) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
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.
setQueryRegex(String) - Method in class org.apache.hadoop.hive.ql.exec.errors.RegexErrorHeuristic
 
setQueryString(String) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
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
 
setQueryType(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueryTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setQueued() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setReadColumnIDs(Configuration, ArrayList<Integer>) - Static method in class org.apache.hadoop.hive.serde2.ColumnProjectionUtils
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
 
setReduceTasksIsSet(boolean) - 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
 
setRenewer_kerberos_principal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
setRenewer_kerberos_principal_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
setRenewer_kerberos_principal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
setRenewer_kerberos_principal_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
setRepairPartitions(boolean) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setReplace(boolean) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setReporter(Reporter) - Method in class org.apache.hadoop.hive.ql.exec.Operator
 
setResDir(Path) - Method in class org.apache.hadoop.hive.ql.Context
 
setResFile(Path) - Method in class org.apache.hadoop.hive.ql.Context
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.DescDatabaseDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.DescFunctionDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
setResFile(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
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
 
setResult(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
setResult(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
setResult(DoubleWritable) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFVariance.GenericUDAFVarianceEvaluator
 
setResultBucketMaxSize(int) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
sets the value for resultBucketMaxSize.
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.HashTableSinkDesc
 
setRetainList(Map<Byte, List<Integer>>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setRetention(int) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setRetention(int) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setRetention(int) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setRetentionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setReversedExprs(Map<String, Byte>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setReversedExprs(Map<String, Byte>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setRevokeDesc(RevokeDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setRight(int) - Method in class org.apache.hadoop.hive.ql.parse.JoinCond
 
setRight(int) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setRightAliases(String[]) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
setRole(Role) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
setRole(MRole) - Method in class org.apache.hadoop.hive.metastore.model.MRoleMap
 
setRole_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
setRole_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setRole_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setRole_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
setRole_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
setRole_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
setRoleDDLDesc(RoleDDLDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setRoleIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
setRoleName(String) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setRoleName(String) - Method in class org.apache.hadoop.hive.metastore.model.MRole
 
setRoleNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
setRoleOwnerName(String) - Method in class org.apache.hadoop.hive.ql.plan.RoleDDLDesc
 
setRolePrivileges(Map<String, List<PrivilegeGrantInfo>>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setRolePrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setRoles(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.GrantRevokeRoleDDL
 
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
 
setRootPath(String) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setRoots(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setRootsIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
setRootTask(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(ArrayList<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.plan.ExplainWork
 
setRootTasks(ArrayList<Task<? extends Serializable>>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
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
 
setRowResolver(RowResolver) - Method in class org.apache.hadoop.hive.ql.parse.OpParseContext
 
setRowSchema(RowSchema) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setRslvMap(HashMap<String, LinkedHashMap<String, ColumnInfo>>) - Method in class org.apache.hadoop.hive.ql.parse.RowResolver
 
setRunDisabled(String) - Method in class org.apache.hadoop.hive.ant.QTestGenTask
 
setRunning(boolean) - Method in class org.apache.hadoop.hive.ql.exec.TaskResult
 
setS(String) - Method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
setSampleDescr(FilterDesc.sampleDesc) - Method in class org.apache.hadoop.hive.ql.plan.FilterDesc
 
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(List<FieldSchema>) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setSchema(String) - Method in class org.apache.hadoop.hive.ql.plan.SchemaDesc
 
setScriptCmd(String) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setScriptErrInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setScriptInputInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setScriptOutputInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.ScriptDesc
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setSd(StorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setSd(MStorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MIndex
 
setSd(MStorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setSd(MStorageDescriptor) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setSdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
setSdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setSdIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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
 
setSerDe(SerDe, ObjectInspector) - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
 
setSerde(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setSerdeClassName(String) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
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
 
setSerdeInfoIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setSerdeName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setSerdeParam(SerDeInfo, Properties, String) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
setSerdeParam(String, String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setSerdeProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setSerdeProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
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
 
setSerializationLibIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
setSerializationNullFormat(String) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setSerName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
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
 
setShowDatabasesDesc(ShowDatabasesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowFuncsDesc(ShowFunctionsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowGrantDesc(ShowGrantDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowIndexesDesc(ShowIndexesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowLocksDesc(ShowLocksDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowPartsDesc(ShowPartitionsDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowTblsDesc(ShowTablesDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setShowTblStatusDesc(ShowTableStatusDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setSignature(ArrayList<ColumnInfo>) - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
setSkewJoinJobCounter(LongWritable) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
setSkewKeyDefinition(int) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setSkewKeyDefinition(int) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
set skew key definition.
setSkewKeysValuesTables(Map<Byte, TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setSkewKeysValuesTables(Map<Byte, TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
setSmallKeysDirMap(Map<Byte, Map<Byte, String>>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setSmallKeysDirMap(Map<Byte, Map<Byte, String>>) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
set the mapping from tbl to dir for small keys.
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(ArrayList<Order>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setSortColsIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
setSortColumns(ArrayList<Order>) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setSourceDir(String) - Method in class org.apache.hadoop.hive.ql.plan.LoadDesc
 
setSourceDirs(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setSPColNames(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setSplitNum(int) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setSPPath(String) - Method in class org.apache.hadoop.hive.ql.plan.DynamicPartitionCtx
 
setSQLState(String) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
setSQLStateIsSet(boolean) - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
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
 
setSSIsSilent(boolean) - Method in class org.apache.hadoop.hive.hwi.HWISessionItem
This is a chained call to SessionState.setIsSilent().
setStageAttributes(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageCounters(Map<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageCountersIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageGraph(Graph) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStageGraphIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStageId(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageID(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setStageIdIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageList(List<Stage>) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStageListIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStageType(StageType) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStageTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStarted() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStarted(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setStarted() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setStarted(HashSet<String>) - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setStartedIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setState(JobTrackerState) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setStateIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setStaticSpec(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setStatsAggPrefix(String) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
Set the stats aggregation key.
setStatsAggPrefix(String) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setStorageHandler(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableDesc
 
setStorageHandler(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setStorageHandler(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setStreamAliases(List<String>) - Method in class org.apache.hadoop.hive.ql.parse.QBJoinTree
 
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
 
setStructFieldData(Object, StructField, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
setStructFieldData(Object, StructField, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.SettableStructObjectInspector
Modify the value of a field.
setStructFieldData(Object, StructField, Object) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardStructObjectInspector
 
setSubqAlias(String, QBExpr) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setSuccess(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_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_role_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setSuccess(Database) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setSuccess(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
setSuccess(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setSuccess(Index) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setSuccess(List<Index>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setSuccess(Partition) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setSuccess(List<Partition>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setSuccess(PrincipalPrivilegeSet) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setSuccess(List<FieldSchema>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setSuccess(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(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setSuccess(List<HiveObjectPrivilege>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setSuccess(List<Role>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setSuccess(Map<String, String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setSuccess(long) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setSuccess(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setSuccess(List<String>) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setSuccess(String) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setSuccess(HiveClusterStatus) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setSuccess(QueryPlan) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setSuccess(Schema) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setSuccess(Schema) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
setSwitchDatabaseDesc(SwitchDatabaseDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
Set Switch Database descriptor
setT(Table) - Method in class org.apache.hadoop.hive.ql.hooks.ReadEntity
 
setT(Table) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setTabAlias(LineageInfo.TableAliasInfo) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.BaseColumnInfo
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcCtx
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprProcCtx
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.ExprPrunerInfo
 
setTabAlias(String, String) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setTabAlias(String) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
setTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MPartition
 
setTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MTableColumnPrivilege
 
setTable(MTable) - Method in class org.apache.hadoop.hive.metastore.model.MTablePrivilege
 
setTable(Table) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.TableAliasInfo
 
setTable(Table) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Should be only used by serialization.
setTable(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.LoadTableDesc
 
setTable(boolean) - Method in class org.apache.hadoop.hive.ql.plan.PrivilegeObjectDesc
 
setTable_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setTable_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
setTable_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
setTable_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.exec.persistence.RowContainer
 
setTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
setTableDesc(CreateTableDesc) - Method in class org.apache.hadoop.hive.ql.parse.QB
 
setTableDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.PartitionDesc
 
SettableDoubleObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableDoubleObjectInspector can set a double value to an object.
SettableFloatObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableFloatObjectInspector can set a float value to an object.
setTableInfo(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
SettableIntObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableIntObjectInspector can set an int value to an object.
SettableListObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
SettableListObjectInspector.
SettableLongObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector.primitive
A SettableLongObjectInspector can set a long value to an object.
SettableMapObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
SettableMapObjectInspector.
setTableName(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.metadata.CheckResult.PartitionResult
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.AddPartitionDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableLikeDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.DescTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropIndexDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.DropTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.LockTableDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.MsckDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
setTableName(String) - Method in class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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.
SettableStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
SettableStructObjectInspector.
SettableStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.SettableStructObjectInspector
 
setTableType(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setTableType(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setTableType(TableType) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setTableTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
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
 
setTag(byte) - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
setTagOrder(Byte[]) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setTagOrder(Byte[]) - Method in class org.apache.hadoop.hive.ql.plan.JoinDesc
The order in which tables should be processed when joining.
setTagToAlias(HashMap<Byte, String>) - Method in class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
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
 
setTargetDirs(List<String>) - Method in class org.apache.hadoop.hive.ql.plan.LoadMultiFilesDesc
 
setTaskAttributes(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskAttributesIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskCounters(String, String, Counters) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Serialize the task counters and set as a task property.
setTaskCounters(Map<String, Long>) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskCountersIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskId(String) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskIdIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskList(List<Task>) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setTaskListIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
setTaskPlan(String, Operator<? extends Serializable>, MapredWork, boolean, GenMRProcContext) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
set the current task in the mapredWork.
setTaskPlan(String, Operator<? extends Serializable>, MapredWork, boolean, GenMRProcContext, PrunedPartitionList) - Static method in class org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils
set the current task in the mapredWork.
setTaskPlan(String, String, Operator<? extends 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.
setTaskTag(int) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
setTaskTmpDir(String) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
setTaskTrackers(int) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setTaskTrackersIsSet(boolean) - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
setTaskType(TaskType) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTaskTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
setTbl(Table) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
setTbl(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.HashTableDummyDesc
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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.append_partition_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setTbl_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setTbl_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
setTblDataDone(boolean) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setTblDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setTblDir(String) - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
setTblIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
setTblProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateIndexDesc
 
setTblProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateTableDesc
 
setTblProps(Map<String, String>) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
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.
setTmpFileURI(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork
 
setTmpHDFSFileURI(String) - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
setToken_signature(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
setToken_signatureIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
setToken_str_form(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
setToken_str_form(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
setToken_str_formIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
setToken_str_formIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
setTokenRewriteStream(TokenRewriteStream) - Method in class org.apache.hadoop.hive.ql.Context
Set the token rewrite stream being used to parse the current top-level SQL statement.
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
 
setTotalFiles(int) - Method in class org.apache.hadoop.hive.ql.plan.FileSinkDesc
 
setTPartition(Partition) - Method in class org.apache.hadoop.hive.ql.metadata.Partition
Should be only used by serialization.
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
This function should only be called by Java serialization.
setTTDesc(TableDesc) - Method in class org.apache.hadoop.hive.ql.optimizer.GenMRProcContext.GenMRMapJoinCtx
 
setTyp(WriteEntity.Type) - Method in class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
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(LineageInfo.DependencyType) - Method in class org.apache.hadoop.hive.ql.hooks.LineageInfo.Dependency
 
setType(AlterTableDesc.AlterTableTypes) - Method in class org.apache.hadoop.hive.ql.plan.AlterTableSimpleDesc
 
setType(ArchiveWork.ArchiveActionType) - Method in class org.apache.hadoop.hive.ql.plan.ArchiveWork
 
setType(int) - Method in class org.apache.hadoop.hive.ql.plan.JoinCondDesc
 
setType(PrincipalType) - Method in class org.apache.hadoop.hive.ql.plan.PrincipalDesc
 
setType1(String) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setType1(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setType1IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setType2(String) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setType2(String) - Method in class org.apache.hadoop.hive.metastore.model.MType
 
setType2IsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Type
 
setTypeFilter(RecordTypeInfo) - Static method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
setTypeInfo(PrimitiveTypeInfo) - Method in class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
setTypeInfo(TypeInfo) - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeDesc
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.FieldSchema
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
setTypeIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
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.udf.generic.GenericUDFBridge
 
setUdfName(String) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBridge
 
setUgi(UserGroupInformation) - Method in class org.apache.hadoop.hive.ql.hooks.HookContext
 
setUnderscore_int(int) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setUnderscore_intIsSet(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
setUnicodeStream(int, InputStream, int) - Method in class org.apache.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.
setUnlockTblDesc(UnlockTableDesc) - Method in class org.apache.hadoop.hive.ql.plan.DDLWork
 
setUnparseTranslator(UnparseTranslator) - Method in class org.apache.hadoop.hive.ql.parse.TypeCheckCtx
 
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.TestEmbeddedHiveMetaStore
 
setUp() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
setUp() - Method in class org.apache.hadoop.hive.metastore.TestRemoteHiveMetaStore
 
setUp() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
setUp() - Method in class org.apache.hadoop.hive.ql.exec.TestExpressionEvaluator
 
setUp() - Method in class org.apache.hadoop.hive.ql.exec.TestOperators
 
setUp() - Method in class org.apache.hadoop.hive.ql.history.TestHiveHistory
 
setUp() - Method in class org.apache.hadoop.hive.ql.io.TestSymlinkTextInputFormat
 
setUp() - Method in class org.apache.hadoop.hive.ql.metadata.TestHive
 
setUp() - Method in class org.apache.hadoop.hive.ql.metadata.TestHiveMetaStoreChecker
 
setUp() - Method in class org.apache.hadoop.hive.ql.util.TestDosToUnix
 
setUp() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
setupContext(Iterator<Path>, Iterator<PartitionDesc>) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
used for bucket map join.
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
 
setUser(String) - Method in class org.apache.hadoop.hive.hwi.HWIAuth
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setUser_name(String) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
setUser_nameIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
setUserPrivileges(Map<String, List<PrivilegeGrantInfo>>) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
setUserPrivilegesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
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
 
setValueCols(ArrayList<ExprNodeDesc>) - Method in class org.apache.hadoop.hive.ql.plan.ReduceSinkDesc
 
setValueFilteredTblDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
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
 
setValuesIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
setValueTblDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
setValueTblDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.MapJoinDesc
 
setValueTblFilteredDescs(List<TableDesc>) - Method in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
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
 
setVersionIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Version
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setViewExpandedText(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setViewExpandedTextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setViewName(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.metastore.model.MTable
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
setViewOriginalText(String) - Method in class org.apache.hadoop.hive.ql.plan.CreateViewDesc
 
setViewOriginalTextIsSet(boolean) - Method in class org.apache.hadoop.hive.metastore.api.Table
 
setVirtualCol(boolean) - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
 
setVirtualCols(List<VirtualColumn>) - Method in class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
setWhrExprForClause(String, ASTNode) - Method in class org.apache.hadoop.hive.ql.parse.QBParseInfo
 
setWork(FetchWork) - Method in class org.apache.hadoop.hive.ql.exec.FetchOperator
 
setWork(T) - Method in class org.apache.hadoop.hive.ql.exec.Task
 
ShimLoader - Class in org.apache.hadoop.hive.shims
ShimLoader.
shortName() - Static method in class org.apache.hadoop.hive.serde2.TestSerDe
 
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.
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
 
shouldBeSkipped(String) - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
shouldGetColsFromSerDe(String) - Static method in class org.apache.hadoop.hive.serde2.SerDeUtils
 
shouldIgnoreField(String) - Method in class org.apache.hadoop.hive.serde2.objectinspector.ReflectionStructObjectInspector
 
SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
ShowDatabasesDesc - Class in org.apache.hadoop.hive.ql.plan
ShowDatabasesDesc.
ShowDatabasesDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
ShowDatabasesDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
ShowDatabasesDesc(Path, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowDatabasesDesc
 
ShowFunctionsDesc - Class in org.apache.hadoop.hive.ql.plan
ShowFunctionsDesc.
ShowFunctionsDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
ShowFunctionsDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
ShowFunctionsDesc(Path, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowFunctionsDesc
 
ShowGrantDesc - Class in org.apache.hadoop.hive.ql.plan
 
ShowGrantDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
ShowGrantDesc(String, PrincipalDesc, PrivilegeObjectDesc, List<String>) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowGrantDesc
 
showGrants() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ShowIndexesDesc - Class in org.apache.hadoop.hive.ql.plan
ShowIndexesDesc.
ShowIndexesDesc(String, Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowIndexesDesc
 
ShowLocksDesc - Class in org.apache.hadoop.hive.ql.plan
ShowLocksDesc.
ShowLocksDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
ShowLocksDesc(Path, String, HashMap<String, String>, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowLocksDesc
 
ShowPartitionsDesc - Class in org.apache.hadoop.hive.ql.plan
ShowPartitionsDesc.
ShowPartitionsDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
ShowPartitionsDesc(String, Path, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowPartitionsDesc
 
showPrivilegeGrant(HiveObjectType, String, PrincipalType, String, String, List<String>, String) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
showRoleGrant(String, PrincipalType) - Method in class org.apache.hadoop.hive.ql.metadata.Hive
 
showRoleGrants() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
showStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
showStmtIdentifier() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
ShowTablesDesc - Class in org.apache.hadoop.hive.ql.plan
ShowTablesDesc.
ShowTablesDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
ShowTablesDesc(Path) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
ShowTablesDesc(Path, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
ShowTablesDesc(Path, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTablesDesc
 
ShowTableStatusDesc - Class in org.apache.hadoop.hive.ql.plan
ShowTableStatusDesc.
ShowTableStatusDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
For serializatino use only.
ShowTableStatusDesc(String, String, String) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
ShowTableStatusDesc(String, String, String, HashMap<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.ShowTableStatusDesc
 
showTime(long) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
shutdown() - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
shutdown() - Method in class org.apache.hadoop.hive.metastore.ObjectStore
 
shutdown() - Method in interface org.apache.hadoop.hive.metastore.RawStore
 
shutdown() - Method in class org.apache.hadoop.hive.ql.QTestUtil
 
shutdown() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.MiniDFSShim
 
signature() - Static method in class org.apache.hadoop.hive.ql.io.RecordTestObj
 
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
 
SimpleGenericUDAFParameterInfo - Class in org.apache.hadoop.hive.ql.udf.generic
A simple implementation of GenericUDAFParameterInfo.
SimpleGenericUDAFParameterInfo(TypeInfo[], boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.SimpleGenericUDAFParameterInfo
 
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() - Method in class org.apache.hadoop.hive.ql.exec.persistence.AbstractRowContainer
Get the number of elements in the RowContainer.
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.HashMapWrapper
 
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinRowContainer
Get the number of elements in the RowContainer.
size() - Method in class org.apache.hadoop.hive.ql.exec.persistence.RowContainer
Get the number of elements in the RowContainer.
size() - Method in class org.apache.hadoop.hive.ql.udf.generic.NGramEstimator
Returns the number of n-grams in our buffer.
size() - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Returns the number of valid elements.
skewJoinEnabled(HiveConf, JoinOperator) - Static method in class org.apache.hadoop.hive.ql.optimizer.physical.GenMRSkewJoinProcessor
 
SkewJoinHandler - Class in org.apache.hadoop.hive.ql.exec
At runtime in Join, we output big keys in one table into one corresponding directories, and all same keys in other tables into different dirs(one for each table).
SkewJoinHandler(CommonJoinOperator<? extends Serializable>) - Constructor for class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
SkewJoinProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.physical
Node processor factory for skew join resolver.
SkewJoinProcFactory.SkewJoinDefaultProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
SkewJoinDefaultProcessor.
SkewJoinProcFactory.SkewJoinDefaultProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory.SkewJoinDefaultProcessor
 
SkewJoinProcFactory.SkewJoinJoinProcessor - Class in org.apache.hadoop.hive.ql.optimizer.physical
SkewJoinJoinProcessor.
SkewJoinProcFactory.SkewJoinJoinProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinProcFactory.SkewJoinJoinProcessor
 
SkewJoinResolver - Class in org.apache.hadoop.hive.ql.optimizer.physical
An implementation of PhysicalPlanResolver.
SkewJoinResolver() - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver
 
SkewJoinResolver.SkewJoinProcCtx - Class in org.apache.hadoop.hive.ql.optimizer.physical
A container of current task and parse context.
SkewJoinResolver.SkewJoinProcCtx(Task<? extends Serializable>, ParseContext) - Constructor for class org.apache.hadoop.hive.ql.optimizer.physical.SkewJoinResolver.SkewJoinProcCtx
 
skip(long) - Method in class org.apache.hadoop.hive.common.io.NonSyncByteArrayInputStream
skip(long) - Method in class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
skip(byte) - Method in interface org.apache.hadoop.hive.serde2.thrift.SkippableTProtocol
 
skip(byte) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
Skip past the current field Just increments the field index counter.
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.
slurpRaw(byte[], int, int) - Static method in class org.apache.hadoop.hive.ql.io.RecordTestObj.Comparator
 
SMALLINT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
SMBJoinDesc - Class in org.apache.hadoop.hive.ql.plan
 
SMBJoinDesc(MapJoinDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
SMBJoinDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SMBJoinDesc
 
SMBMapJoinOperator - Class in org.apache.hadoop.hive.ql.exec
Sorted Merge Map Join Operator.
SMBMapJoinOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
SMBMapJoinOperator(AbstractMapJoinOperator<? extends MapJoinDesc>) - Constructor for class org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator
 
soi0 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
soi1 - Variable in class org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare
 
sortByClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SortedMergeBucketMapJoinOptimizer - Class in org.apache.hadoop.hive.ql.optimizer
 
SortedMergeBucketMapJoinOptimizer() - Constructor for class org.apache.hadoop.hive.ql.optimizer.SortedMergeBucketMapJoinOptimizer
 
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.
specPath - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
specType - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
spillTableDesc - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
spillTableDesc - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
split - Variable in class org.apache.hadoop.hive.ql.io.BucketizedHiveRecordReader
 
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
 
srcTables - Static variable in class org.apache.hadoop.hive.ql.QTestUtil
 
ss - Variable in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
Stage - Class in org.apache.hadoop.hive.ql.plan.api
 
Stage() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Stage
 
Stage(String, StageType, Map<String, String>, Map<String, Long>, List<Task>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Stage
 
Stage(Stage) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Stage
Performs a deep copy on other.
Stage._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
StageType - Enum in org.apache.hadoop.hive.ql.plan.api
 
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
 
StandardUnionObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
StandardUnionObjectInspector works on union data that is stored as UnionObject.
StandardUnionObjectInspector(List<ObjectInspector>) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
StandardUnionObjectInspector.StandardUnion - Class in org.apache.hadoop.hive.serde2.objectinspector
 
StandardUnionObjectInspector.StandardUnion() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
StandardUnionObjectInspector.StandardUnion(byte, Object) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
STAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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
 
startCol - Variable in class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
 
startDelegationTokenSecretManager(Configuration) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
started - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
started() - Method in class org.apache.hadoop.hive.ql.exec.Task
 
startFunction(String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
startFunction(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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
 
startMetaStore(int, HadoopThriftAuthBridge) - Static method in class org.apache.hadoop.hive.metastore.HiveMetaStore
Start Metastore based on a passed HadoopThriftAuthBridge
startPartitionFunction(String, String, String, List<String>) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
startQuery(String, String) - Method in class org.apache.hadoop.hive.ql.history.HiveHistory
Called at the start of job Driver.run().
startScope(String) - Static method in class org.apache.hadoop.hive.common.metrics.Metrics
 
startServer(String, int) - Method in interface org.apache.hadoop.hive.shims.JettyShims
 
startTableFunction(String, String, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStore.HMSHandler
 
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.
startWalking(Collection<Node>, HashMap<Node, Object>) - Method in class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
starting point for walking.
Stat - Class in org.apache.hadoop.hive.ql.exec
 
Stat() - Constructor for class org.apache.hadoop.hive.ql.exec.Stat
 
state - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
statement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
staticFlag - Static variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
StatsAggregator - Interface in org.apache.hadoop.hive.ql.stats
An interface for any possible implementation for gathering statistics.
StatsFactory - Class in org.apache.hadoop.hive.ql.stats
A factory of stats publisher and aggregator implementations of the StatsPublisher and StatsAggregator interfaces.
StatsFactory() - Constructor for class org.apache.hadoop.hive.ql.stats.StatsFactory
 
statsMap - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
StatsPublisher - Interface in org.apache.hadoop.hive.ql.stats
An interface for any possible implementation for publishing statics.
StatsSetupConst - Class in org.apache.hadoop.hive.ql.stats
A class that defines the constant strings used by the statistics implementation.
StatsSetupConst() - Constructor for class org.apache.hadoop.hive.ql.stats.StatsSetupConst
 
StatsTask - Class in org.apache.hadoop.hive.ql.exec
StatsTask implementation.
StatsTask() - Constructor for class org.apache.hadoop.hive.ql.exec.StatsTask
 
StatsWork - Class in org.apache.hadoop.hive.ql.plan
ConditionalStats.
StatsWork() - Constructor for class org.apache.hadoop.hive.ql.plan.StatsWork
 
StatsWork(BaseSemanticAnalyzer.tableSpec) - Constructor for class org.apache.hadoop.hive.ql.plan.StatsWork
 
StatsWork(LoadTableDesc) - Constructor for class org.apache.hadoop.hive.ql.plan.StatsWork
 
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.
StorageDescriptor._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
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.
StructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
 
structType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
StructTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
StructTypeInfo represents the TypeInfo of a struct.
StructTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.StructTypeInfo
For java serialization use only.
subQuerySource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
subscribeFeed(Task<? extends Serializable>) - Method in class org.apache.hadoop.hive.ql.exec.Task
Subscribe the feed of publisher.
substitute(HiveConf, String) - Method in class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
SubStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
SubsetStructObjectInspector implement a wrapper around a base object inspector (baseOI) such that when the row corresponding to the baseOI is given together with this object inspector, it will mask out some fields in the row as if they are not there.
SubStructObjectInspector(StructObjectInspector, int, int) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.SubStructObjectInspector
Create a new Object Inspector based on a base object inspector and the subset of columns will be inspected (from startCol to startCol+numCols).
suffix - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
supportColumnLevel() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
supportCombineFileInputFormat() - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
supportDBLevel() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
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
 
supportTableLevel() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
SwitchDatabaseDesc - Class in org.apache.hadoop.hive.ql.plan
SwitchDatabaseDesc.
SwitchDatabaseDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.SwitchDatabaseDesc
 
SwitchDatabaseDesc(String) - Constructor for class org.apache.hadoop.hive.ql.plan.SwitchDatabaseDesc
 
switchDatabaseStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SwitchTo(int) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarTokenManager
Switch to specified lex state.
SymlinkTextInputFormat - Class in org.apache.hadoop.hive.ql.io
Symlink file is a text file which contains a list of filename / dirname.
SymlinkTextInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
 
SymlinkTextInputFormat.SymlinkTextInputSplit - Class in org.apache.hadoop.hive.ql.io
This input split wraps the FileSplit generated from TextInputFormat.getSplits(), while setting the original link file path as job input path.
SymlinkTextInputFormat.SymlinkTextInputSplit() - Constructor for class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
 
SymlinkTextInputFormat.SymlinkTextInputSplit(Path, FileSplit) - Constructor for class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
 
sync(long) - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Seek to the next sync mark past a given position.
sync() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Writer
create a sync point.
SYNC_INTERVAL - Static variable in class org.apache.hadoop.hive.ql.io.RCFile
The number of bytes between sync points.
syncSeen() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns true iff the previous call to next passed a sync mark.
sysFuncNames() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
SYSTEM_PREFIX - Static variable in class org.apache.hadoop.hive.ql.processors.SetProcessor
 

T

tabCode - Static variable in class org.apache.hadoop.hive.ql.exec.Utilities
 
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>, String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.Table
 
Table(Table) - Constructor for class org.apache.hadoop.hive.metastore.api.Table
Performs a deep copy on other.
Table - Class in org.apache.hadoop.hive.ql.metadata
A Hive Table: is a fundamental unit of data in Hive that shares a common schema/DDL.
Table() - Constructor for class org.apache.hadoop.hive.ql.metadata.Table
Used only for serialization.
Table(Table) - Constructor for class org.apache.hadoop.hive.ql.metadata.Table
 
Table(String, String) - Constructor for class org.apache.hadoop.hive.ql.metadata.Table
 
Table._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tableAlias() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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.
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, String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
 
tableExists(String) - Method in class org.apache.hadoop.hive.metastore.HiveMetaStoreClient
Deprecated. 
tableExists(String, String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
 
tableExists(String) - Method in interface org.apache.hadoop.hive.metastore.IMetaStoreClient
Deprecated. As of release 0.6.0 replaced by IMetaStoreClient.tableExists(String, String). This method will be removed in release 0.7.0.
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 - Variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec
 
tableName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableOrColumn() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableOrPartition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tablePartition() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tablePartitionPrefix() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tableProperties() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tablePropertiesList() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tablePropertiesPrefixed() - 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
 
TableScanDesc(String, List<VirtualColumn>) - Constructor for class org.apache.hadoop.hive.ql.plan.TableScanDesc
 
TableScanOperator - Class in org.apache.hadoop.hive.ql.exec
Table Scan Operator If the data is coming from the map-reduce framework, just forward it.
TableScanOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.TableScanOperator
 
tableSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TableType - Enum in org.apache.hadoop.hive.metastore
Typesafe enum for types of tables described by the metastore.
tabSize - Variable in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
tabTypeExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tag - Variable in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector.StandardUnion
 
tagOrder - Variable in class org.apache.hadoop.hive.ql.plan.HashTableSinkDesc
 
tagOrder - Variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
tail() - Method in class org.apache.hadoop.hive.ql.exec.persistence.MRU
Get the least recently used.
tar(String, String[], String) - Static method in class org.apache.hadoop.hive.common.FileUtils
Archive all the files in the inputFiles into outputFile
Task<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
Task implementation.
Task() - Constructor for class org.apache.hadoop.hive.ql.exec.Task
 
Task - Class in org.apache.hadoop.hive.ql.plan.api
 
Task() - Constructor for class org.apache.hadoop.hive.ql.plan.api.Task
 
Task(String, TaskType, Map<String, String>, Map<String, Long>, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Task
 
Task(Task) - Constructor for class org.apache.hadoop.hive.ql.plan.api.Task
Performs a deep copy on other.
Task._Fields - Enum in org.apache.hadoop.hive.ql.plan.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Task.FeedType - Enum in org.apache.hadoop.hive.ql.exec
 
taskClass - Variable in class org.apache.hadoop.hive.ql.exec.TaskFactory.taskTuple
 
taskCleanup() - Method in class org.apache.hadoop.hive.ql.Driver
Cleans up remaining tasks in case of failure
taskCounters - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
TaskExecutionException - Exception in org.apache.hadoop.hive.ql.exec
Exception thrown by any task processor to signal a problem with task execution.
TaskExecutionException(String) - Constructor for exception org.apache.hadoop.hive.ql.exec.TaskExecutionException
 
TaskExecutionException(String, Throwable) - Constructor for exception org.apache.hadoop.hive.ql.exec.TaskExecutionException
 
TaskExecutionException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.exec.TaskExecutionException
 
TaskFactory - Class in org.apache.hadoop.hive.ql.exec
TaskFactory implementation.
TaskFactory.taskTuple<T extends Serializable> - Class in org.apache.hadoop.hive.ql.exec
taskTuple.
TaskFactory.taskTuple(Class<T>, Class<? extends Task<T>>) - Constructor for class org.apache.hadoop.hive.ql.exec.TaskFactory.taskTuple
 
TaskGraphWalker - Class in org.apache.hadoop.hive.ql.lib
base class for operator graph walker this class takes list of starting ops and walks them one by one.
TaskGraphWalker(Dispatcher) - Constructor for class org.apache.hadoop.hive.ql.lib.TaskGraphWalker
Constructor.
TaskGraphWalker.TaskGraphWalkerContext - Class in org.apache.hadoop.hive.ql.lib
 
TaskGraphWalker.TaskGraphWalkerContext(HashMap<Node, Object>) - Constructor for class org.apache.hadoop.hive.ql.lib.TaskGraphWalker.TaskGraphWalkerContext
 
taskHandle - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
TaskHandle - Class in org.apache.hadoop.hive.ql.exec
TaskHandle.
TaskHandle() - Constructor for class org.apache.hadoop.hive.ql.exec.TaskHandle
 
TaskLogProcessor - Class in org.apache.hadoop.hive.ql.exec.errors
TaskLogProcessor reads the logs from failed task attempts and tries to figure out what the cause of the error was using various heuristics.
TaskLogProcessor(JobConf) - Constructor for class org.apache.hadoop.hive.ql.exec.errors.TaskLogProcessor
 
TaskResult - Class in org.apache.hadoop.hive.ql.exec
TaskResult implementation.
TaskResult() - Constructor for class org.apache.hadoop.hive.ql.exec.TaskResult
 
TaskRunner - Class in org.apache.hadoop.hive.ql.exec
TaskRunner implementation.
TaskRunner(Task<? extends Serializable>, TaskResult) - Constructor for class org.apache.hadoop.hive.ql.exec.TaskRunner
 
taskTag - Variable in class org.apache.hadoop.hive.ql.exec.Task
 
TaskType - Enum in org.apache.hadoop.hive.ql.plan.api
 
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
 
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.TestEmbeddedHiveMetaStore
 
tearDown() - Method in class org.apache.hadoop.hive.ql.history.TestHiveHistory
 
tearDown() - Method in class org.apache.hadoop.hive.ql.io.TestSymlinkTextInputFormat
 
tearDown() - Method in class org.apache.hadoop.hive.ql.metadata.TestHive
 
tearDown() - Method in class org.apache.hadoop.hive.ql.metadata.TestHiveMetaStoreChecker
 
tearDown() - Method in class org.apache.hadoop.hive.ql.QTestUtil.QTestSetup
 
tearDown() - Method in class org.apache.hadoop.hive.ql.util.TestDosToUnix
 
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.
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.GenericUDAFCollectSet.GenericUDAFMkSetEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovarianceSample.GenericUDAFCovarianceSampleEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Get final aggregation result.
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator
 
terminate(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.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.UDAFPercentile.PercentileLongArrayEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxDoubleEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxFloatEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxIntEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxLongEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxShortEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxStringEvaluator
 
terminate() - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.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.GenericUDAFCollectSet.GenericUDAFMkSetEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCount.GenericUDAFCountEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFCovariance.GenericUDAFCovarianceEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator
Get partial aggregation result.
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMax.GenericUDAFMaxEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFMin.GenericUDAFMinEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFnGrams.GenericUDAFnGramEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDAFPercentileApprox.GenericUDAFPercentileApproxEvaluator
 
terminatePartial(GenericUDAFEvaluator.AggregationBuffer) - Method in class org.apache.hadoop.hive.ql.udf.generic.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.UDAFPercentile.PercentileLongArrayEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxDoubleEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxFloatEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxIntEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxLongEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxShortEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxStringEvaluator
 
terminatePartial() - Method in class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
test1ApacheLogFormat() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
Tests a sample apache log format.
testAccuracy1() - Method in class org.apache.hadoop.hive.ql.io.TestSymlinkTextInputFormat
Test scenario: Two data directories, one symlink file that contains two paths each point to a file in one of data directories.
testAccuracy2() - Method in class org.apache.hadoop.hive.ql.io.TestSymlinkTextInputFormat
Scenario: Empty input directory, i.e.
testAlterPartition() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testAlterTable() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testBaseFilterOperator() - Method in class org.apache.hadoop.hive.ql.exec.TestOperators
 
TestBinarySortableSerDe - Class in org.apache.hadoop.hive.serde2.binarysortable
TestBinarySortableSerDe.
TestBinarySortableSerDe() - Constructor for class org.apache.hadoop.hive.serde2.binarysortable.TestBinarySortableSerDe
 
testBinarySortableSerDe() - Method in class org.apache.hadoop.hive.serde2.binarysortable.TestBinarySortableSerDe
 
testCloseForErroneousRCFile() - Method in class org.apache.hadoop.hive.ql.io.TestRCFile
 
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
 
testConversionsBaseResultSet() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testConvertWindowsScriptToUnix() - Method in class org.apache.hadoop.hive.ql.util.TestDosToUnix
 
testDatabase() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testDatabaseMetaData() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testDataTypes() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testDaylightChange() - Method in class org.apache.hadoop.hive.ql.udf.TestUDFDateDiff
Verify differences of dates crossing a daylight savings time change are correct.
testDescribeTable() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
TestDosToUnix - Class in org.apache.hadoop.hive.ql.util
 
TestDosToUnix() - Constructor for class org.apache.hadoop.hive.ql.util.TestDosToUnix
 
testDriverProperties() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
TestDynamicSerDe - Class in org.apache.hadoop.hive.serde2.dynamic_type
TestDynamicSerDe.
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
 
TestEmbeddedHiveMetaStore - Class in org.apache.hadoop.hive.metastore
 
TestEmbeddedHiveMetaStore() - Constructor for class org.apache.hadoop.hive.metastore.TestEmbeddedHiveMetaStore
 
testErrorMessages() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
TestExecDriver - Class in org.apache.hadoop.hive.ql.exec
Mimics the actual query compiler in generating end to end plans and testing them out.
TestExecDriver() - Constructor for class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testExecute() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
TestExpressionEvaluator - Class in org.apache.hadoop.hive.ql.exec
TestExpressionEvaluator.
TestExpressionEvaluator() - Constructor for class org.apache.hadoop.hive.ql.exec.TestExpressionEvaluator
 
testExprNodeColumnEvaluator() - Method in class org.apache.hadoop.hive.ql.exec.TestExpressionEvaluator
 
testExprNodeConversionEvaluator() - Method in class org.apache.hadoop.hive.ql.exec.TestExpressionEvaluator
 
testExprNodeFuncEvaluator() - Method in class org.apache.hadoop.hive.ql.exec.TestExpressionEvaluator
 
testExprNodeSpeed() - Method in class org.apache.hadoop.hive.ql.exec.TestExpressionEvaluator
 
testFailure() - Method in class org.apache.hadoop.hive.ql.io.TestSymlinkTextInputFormat
Scenario: No job input paths.
testFallBack() - Method in class org.apache.hadoop.hive.ql.udf.TestUDFDateAdd
Verify if adding dates across a daylight savings time change from daylight to standard time.
testFallBack() - Method in class org.apache.hadoop.hive.ql.udf.TestUDFDateSub
Verify if subtracting dates across a daylight savings time change from daylight to standard time.
testFetch() - Method in class org.apache.hadoop.hive.service.TestHiveServer
 
testFileSinkOperator() - Method in class org.apache.hadoop.hive.ql.exec.TestOperators
More stuff needs to be added here.
testFilterLastPartition() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
Test filtering based on the value of the last partition
testFilterSinglePartition() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
Test filtering on table with single partition
TestFlatFileInputFormat - Class in org.apache.hadoop.hive.ql.io
TestFlatFileInputFormat.
TestFlatFileInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.TestFlatFileInputFormat
 
testFlatFileInputJava() - Method in class org.apache.hadoop.hive.ql.io.TestFlatFileInputFormat
 
testFlatFileInputRecord() - Method in class org.apache.hadoop.hive.ql.io.TestFlatFileInputFormat
 
testGetAndDropTables() - Method in class org.apache.hadoop.hive.ql.metadata.TestHive
 
testGetClusterStatus() - Method in class org.apache.hadoop.hive.service.TestHiveServer
Test cluster status retrieval.
testGetConfigValue() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
testGetPartitionDescFromPathRecursively() - Method in class org.apache.hadoop.hive.ql.io.TestHiveFileFormatUtils
 
testGetUnixScriptNameFor() - Method in class org.apache.hadoop.hive.ql.util.TestDosToUnix
 
TestHashMapWrapper - Class in org.apache.hadoop.hive.ql.exec
TestHashMapWrapper.
TestHashMapWrapper() - Constructor for class org.apache.hadoop.hive.ql.exec.TestHashMapWrapper
 
testHashMapWrapper() - Method in class org.apache.hadoop.hive.ql.exec.TestHashMapWrapper
 
TestHive - Class in org.apache.hadoop.hive.ql.metadata
TestHive.
TestHive() - Constructor for class org.apache.hadoop.hive.ql.metadata.TestHive
 
testHiveCloseCurrent() - Method in class org.apache.hadoop.hive.ql.metadata.TestHive
Test basic Hive class interaction, that: - We can have different Hive objects throughout the lifetime of this thread.
testHiveDriver() - Method in class org.apache.hadoop.hive.hwi.TestHWISessionManager
 
TestHiveFileFormatUtils - Class in org.apache.hadoop.hive.ql.io
 
TestHiveFileFormatUtils() - Constructor for class org.apache.hadoop.hive.ql.io.TestHiveFileFormatUtils
 
TestHiveHistory - Class in org.apache.hadoop.hive.ql.history
TestHiveHistory.
TestHiveHistory() - Constructor for class org.apache.hadoop.hive.ql.history.TestHiveHistory
 
TestHiveInputOutputBuffer - Class in org.apache.hadoop.hive.ql.io
TestHiveInputOutputBuffer.
TestHiveInputOutputBuffer() - Constructor for class org.apache.hadoop.hive.ql.io.TestHiveInputOutputBuffer
 
TestHiveMetaStore - Class in org.apache.hadoop.hive.metastore
 
TestHiveMetaStore() - Constructor for class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
TestHiveMetaStoreChecker - Class in org.apache.hadoop.hive.ql.metadata
TestHiveMetaStoreChecker.
TestHiveMetaStoreChecker() - Constructor for class org.apache.hadoop.hive.ql.metadata.TestHiveMetaStoreChecker
 
TestHiveServer - Class in org.apache.hadoop.hive.service
TestHiveServer.
TestHiveServer(String) - Constructor for class org.apache.hadoop.hive.service.TestHiveServer
 
testHookLoading() - Method in class org.apache.hadoop.hive.ql.metadata.TestSemanticAnalyzerHookLoading
 
TestHWIServer - Class in org.apache.hadoop.hive.hwi
TestHWIServer.
TestHWIServer(String) - Constructor for class org.apache.hadoop.hive.hwi.TestHWIServer
 
TestHWISessionManager - Class in org.apache.hadoop.hive.hwi
TestHWISessionManager.
TestHWISessionManager(String) - Constructor for class org.apache.hadoop.hive.hwi.TestHWISessionManager
 
testIsWindowsScript() - Method in class org.apache.hadoop.hive.ql.util.TestDosToUnix
 
testJavaPrimitiveObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestStandardObjectInspectors
 
TestJdbcDriver - Class in org.apache.hadoop.hive.jdbc
TestJdbcDriver.
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
Tests LazyArray, LazyMap, LazyStruct and LazyUnion
TestLazyArrayMapStruct() - Constructor for class org.apache.hadoop.hive.serde2.lazy.TestLazyArrayMapStruct
 
TestLazyBinarySerDe - Class in org.apache.hadoop.hive.serde2.lazybinary
TestLazyBinarySerDe.
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.
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.
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.
testLazyUnion() - Method in class org.apache.hadoop.hive.serde2.lazy.TestLazyArrayMapStruct
Test the LazyUnion class.
TestLineageInfo - Class in org.apache.hadoop.hive.ql.tool
TestLineageInfo.
TestLineageInfo() - Constructor for class org.apache.hadoop.hive.ql.tool.TestLineageInfo
 
testMapOperator() - Method in class org.apache.hadoop.hive.ql.exec.TestOperators
 
testMapPlan1() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testMapPlan2() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testMapRedPlan1() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testMapRedPlan2() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testMapRedPlan3() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testMapRedPlan4() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testMapRedPlan5() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testMapRedPlan6() - Method in class org.apache.hadoop.hive.ql.exec.TestExecDriver
 
testMetaDataGetCatalogs() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testMetaDataGetColumns() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testMetaDataGetTables() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testMetaDataGetTableTypes() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testMetastore() - Method in class org.apache.hadoop.hive.service.TestHiveServer
Test metastore call.
TestMTQueries - Class in org.apache.hadoop.hive.ql
Suite for testing running of queries in multi-threaded mode.
TestMTQueries() - Constructor for class org.apache.hadoop.hive.ql.TestMTQueries
 
testMTQueries1() - Method in class org.apache.hadoop.hive.ql.TestMTQueries
 
testNameMethods() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
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.
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.
TestObjectInspectorUtils() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestObjectInspectorUtils
 
testObjectInspectorUtils() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestObjectInspectorUtils
 
TestOperators - Class in org.apache.hadoop.hive.ql.exec
TestOperators.
TestOperators() - Constructor for class org.apache.hadoop.hive.ql.exec.TestOperators
 
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
testPartition() - Method in class org.apache.hadoop.hive.ql.metadata.TestHive
 
TestPartition - Class in org.apache.hadoop.hive.ql.metadata
Test the partition class.
TestPartition() - Constructor for class org.apache.hadoop.hive.ql.metadata.TestPartition
 
testPartition() - Method in class org.apache.hadoop.hive.ql.metadata.TestPartition
Test that the Partition spec is created properly.
testPartitionFilter() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
Tests for list partition by filter functionality.
testPartitionsCheck() - Method in class org.apache.hadoop.hive.ql.metadata.TestHiveMetaStoreChecker
 
TestPlan - Class in org.apache.hadoop.hive.ql.exec
TestPlan.
TestPlan() - Constructor for class org.apache.hadoop.hive.ql.exec.TestPlan
 
testPlan() - Method in class org.apache.hadoop.hive.ql.exec.TestPlan
 
TestProtocolBuffersObjectInspectors - Class in org.apache.hadoop.hive.serde2.objectinspector
TestProtocolBuffersObjectInspectors.
TestProtocolBuffersObjectInspectors() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestProtocolBuffersObjectInspectors
 
testProtocolBuffersObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestProtocolBuffersObjectInspectors
 
testQuotedWrites() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
TestRCFile - Class in org.apache.hadoop.hive.ql.io
TestRCFile.
TestRCFile() - Constructor for class org.apache.hadoop.hive.ql.io.TestRCFile
 
testReadAndWrite() - Method in class org.apache.hadoop.hive.ql.io.TestHiveInputOutputBuffer
 
testReads() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
TestReflectionObjectInspectors - Class in org.apache.hadoop.hive.serde2.objectinspector
TestReflectionObjectInspectors.
TestReflectionObjectInspectors() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestReflectionObjectInspectors
 
testReflectionObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestReflectionObjectInspectors
 
TestRemoteHiveMetaStore - Class in org.apache.hadoop.hive.metastore
 
TestRemoteHiveMetaStore() - Constructor for class org.apache.hadoop.hive.metastore.TestRemoteHiveMetaStore
 
testResultSetMetaData() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testScriptOperator() - Method in class org.apache.hadoop.hive.ql.exec.TestOperators
 
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
 
TestSemanticAnalyzerHookLoading - Class in org.apache.hadoop.hive.ql.metadata
 
TestSemanticAnalyzerHookLoading() - Constructor for class org.apache.hadoop.hive.ql.metadata.TestSemanticAnalyzerHookLoading
 
TestSerDe - Class in org.apache.hadoop.hive.serde2
TestSerDe.
TestSerDe() - Constructor for class org.apache.hadoop.hive.serde2.TestSerDe
 
testServerInit() - Method in class org.apache.hadoop.hive.hwi.TestHWIServer
 
testShowTables() - Method in class org.apache.hadoop.hive.jdbc.TestJdbcDriver
 
testSimpleQuery() - Method in class org.apache.hadoop.hive.ql.history.TestHiveHistory
Check history file output for this query.
testSimpleQuery() - Method in class org.apache.hadoop.hive.ql.tool.TestLineageInfo
 
testSimpleQuery2() - Method in class org.apache.hadoop.hive.ql.tool.TestLineageInfo
 
testSimpleQuery3() - Method in class org.apache.hadoop.hive.ql.tool.TestLineageInfo
 
testSimpleQuery4() - Method in class org.apache.hadoop.hive.ql.tool.TestLineageInfo
 
testSimpleQuery5() - Method in class org.apache.hadoop.hive.ql.tool.TestLineageInfo
 
testSimpleReadAndWrite() - Method in class org.apache.hadoop.hive.ql.io.TestRCFile
 
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
 
testSpringAhead() - Method in class org.apache.hadoop.hive.ql.udf.TestUDFDateAdd
Verify if adding dates across a daylight savings time change from standard to daylight time.
testSpringAhead() - Method in class org.apache.hadoop.hive.ql.udf.TestUDFDateSub
Verify if subtracting dates across a daylight savings time change from standard to daylight time.
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.
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
 
testStandardUnionObjectInspector() - 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*.
TestSymlinkTextInputFormat - Class in org.apache.hadoop.hive.ql.io
Unittest for SymlinkTextInputFormat.
TestSymlinkTextInputFormat() - Constructor for class org.apache.hadoop.hive.ql.io.TestSymlinkTextInputFormat
 
testSynAndSplit() - Method in class org.apache.hadoop.hive.ql.io.TestRCFile
 
testSynchronized() - Method in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
Tests HiveMetaStoreClient.newSynchronizedClient(org.apache.hadoop.hive.metastore.IMetaStoreClient).
testTable() - Method in class org.apache.hadoop.hive.ql.metadata.TestHive
 
testTableCheck() - Method in class org.apache.hadoop.hive.ql.metadata.TestHiveMetaStoreChecker
 
testTBinarySortableProtocol() - Method in class org.apache.hadoop.hive.serde2.dynamic_type.TestDynamicSerDe
 
TestTCTLSeparatedProtocol - Class in org.apache.hadoop.hive.serde2
TestTCTLSeparatedProtocol.
TestTCTLSeparatedProtocol() - Constructor for class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
TestThriftObjectInspectors - Class in org.apache.hadoop.hive.serde2.objectinspector
TestThriftObjectInspectors.
TestThriftObjectInspectors() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestThriftObjectInspectors
 
testThriftObjectInspectors() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestThriftObjectInspectors
 
testThriftTable() - Method in class org.apache.hadoop.hive.ql.metadata.TestHive
Tests create and fetch of a thrift based table.
TestUDFDateAdd - Class in org.apache.hadoop.hive.ql.udf
JUnit test for UDFDateAdd.
TestUDFDateAdd() - Constructor for class org.apache.hadoop.hive.ql.udf.TestUDFDateAdd
 
TestUDFDateDiff - Class in org.apache.hadoop.hive.ql.udf
JUnit test for UDFDateDiff.
TestUDFDateDiff() - Constructor for class org.apache.hadoop.hive.ql.udf.TestUDFDateDiff
 
TestUDFDateSub - Class in org.apache.hadoop.hive.ql.udf
JUnit test for UDFDateSub.
TestUDFDateSub() - Constructor for class org.apache.hadoop.hive.ql.udf.TestUDFDateSub
 
TestUnionStructObjectInspector - Class in org.apache.hadoop.hive.serde2.objectinspector
TestUnionStructObjectInspector.
TestUnionStructObjectInspector() - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.TestUnionStructObjectInspector
 
testUnionStructObjectInspector() - Method in class org.apache.hadoop.hive.serde2.objectinspector.TestUnionStructObjectInspector
 
testWriteAndFullyRead() - Method in class org.apache.hadoop.hive.ql.io.TestRCFile
 
testWriteAndPartialRead() - Method in class org.apache.hadoop.hive.ql.io.TestRCFile
 
testWrites() - Method in class org.apache.hadoop.hive.serde2.TestTCTLSeparatedProtocol
 
TEXTFILE_INPUT - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
TEXTFILE_OUTPUT - Static variable in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
 
TextRecordReader - Class in org.apache.hadoop.hive.ql.exec
TextRecordReader.
TextRecordReader() - Constructor for class org.apache.hadoop.hive.ql.exec.TextRecordReader
 
TextRecordWriter - Class in org.apache.hadoop.hive.ql.exec
TextRecordWriter.
TextRecordWriter() - Constructor for class org.apache.hadoop.hive.ql.exec.TextRecordWriter
 
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.
ThriftByteStreamTypedSerDe(Type, TProtocolFactory, TProtocolFactory) - Constructor for class org.apache.hadoop.hive.serde2.thrift.ThriftByteStreamTypedSerDe
 
ThriftDeserializer - Class in org.apache.hadoop.hive.serde2.thrift
ThriftDeserializer.
ThriftDeserializer() - Constructor for class org.apache.hadoop.hive.serde2.thrift.ThriftDeserializer
 
ThriftHive - Class in org.apache.hadoop.hive.service
 
ThriftHive() - Constructor for class org.apache.hadoop.hive.service.ThriftHive
 
ThriftHive.AsyncClient - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient
 
ThriftHive.AsyncClient.execute_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.execute_call(String, AsyncMethodCallback<ThriftHive.AsyncClient.execute_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.execute_call
 
ThriftHive.AsyncClient.Factory - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.Factory
 
ThriftHive.AsyncClient.fetchAll_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.fetchAll_call(AsyncMethodCallback<ThriftHive.AsyncClient.fetchAll_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchAll_call
 
ThriftHive.AsyncClient.fetchN_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.fetchN_call(int, AsyncMethodCallback<ThriftHive.AsyncClient.fetchN_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchN_call
 
ThriftHive.AsyncClient.fetchOne_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.fetchOne_call(AsyncMethodCallback<ThriftHive.AsyncClient.fetchOne_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchOne_call
 
ThriftHive.AsyncClient.getClusterStatus_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.getClusterStatus_call(AsyncMethodCallback<ThriftHive.AsyncClient.getClusterStatus_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getClusterStatus_call
 
ThriftHive.AsyncClient.getQueryPlan_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.getQueryPlan_call(AsyncMethodCallback<ThriftHive.AsyncClient.getQueryPlan_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getQueryPlan_call
 
ThriftHive.AsyncClient.getSchema_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.getSchema_call(AsyncMethodCallback<ThriftHive.AsyncClient.getSchema_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getSchema_call
 
ThriftHive.AsyncClient.getThriftSchema_call - Class in org.apache.hadoop.hive.service
 
ThriftHive.AsyncClient.getThriftSchema_call(AsyncMethodCallback<ThriftHive.AsyncClient.getThriftSchema_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getThriftSchema_call
 
ThriftHive.AsyncIface - Interface in org.apache.hadoop.hive.service
 
ThriftHive.Client - Class in org.apache.hadoop.hive.service
 
ThriftHive.Client(TProtocol) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Client
 
ThriftHive.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Client
 
ThriftHive.Client.Factory - Class in org.apache.hadoop.hive.service
 
ThriftHive.Client.Factory() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.Client.Factory
 
ThriftHive.execute_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.execute_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
ThriftHive.execute_args(String) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
ThriftHive.execute_args(ThriftHive.execute_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_args
Performs a deep copy on other.
ThriftHive.execute_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.execute_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.execute_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
ThriftHive.execute_result(HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
ThriftHive.execute_result(ThriftHive.execute_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.execute_result
Performs a deep copy on other.
ThriftHive.execute_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchAll_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchAll_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
 
ThriftHive.fetchAll_args(ThriftHive.fetchAll_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_args
Performs a deep copy on other.
ThriftHive.fetchAll_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchAll_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchAll_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
ThriftHive.fetchAll_result(List<String>, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
ThriftHive.fetchAll_result(ThriftHive.fetchAll_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
Performs a deep copy on other.
ThriftHive.fetchAll_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchN_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchN_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
ThriftHive.fetchN_args(int) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
 
ThriftHive.fetchN_args(ThriftHive.fetchN_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_args
Performs a deep copy on other.
ThriftHive.fetchN_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchN_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchN_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
ThriftHive.fetchN_result(List<String>, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
ThriftHive.fetchN_result(ThriftHive.fetchN_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
Performs a deep copy on other.
ThriftHive.fetchN_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchOne_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchOne_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
 
ThriftHive.fetchOne_args(ThriftHive.fetchOne_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_args
Performs a deep copy on other.
ThriftHive.fetchOne_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.fetchOne_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.fetchOne_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
ThriftHive.fetchOne_result(String, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
ThriftHive.fetchOne_result(ThriftHive.fetchOne_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
Performs a deep copy on other.
ThriftHive.fetchOne_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getClusterStatus_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.getClusterStatus_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
 
ThriftHive.getClusterStatus_args(ThriftHive.getClusterStatus_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args
Performs a deep copy on other.
ThriftHive.getClusterStatus_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getClusterStatus_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.getClusterStatus_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
ThriftHive.getClusterStatus_result(HiveClusterStatus, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
ThriftHive.getClusterStatus_result(ThriftHive.getClusterStatus_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
Performs a deep copy on other.
ThriftHive.getClusterStatus_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getQueryPlan_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.getQueryPlan_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
 
ThriftHive.getQueryPlan_args(ThriftHive.getQueryPlan_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args
Performs a deep copy on other.
ThriftHive.getQueryPlan_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getQueryPlan_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.getQueryPlan_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
ThriftHive.getQueryPlan_result(QueryPlan, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
ThriftHive.getQueryPlan_result(ThriftHive.getQueryPlan_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
Performs a deep copy on other.
ThriftHive.getQueryPlan_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getSchema_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.getSchema_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
ThriftHive.getSchema_args(ThriftHive.getSchema_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
Performs a deep copy on other.
ThriftHive.getSchema_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getSchema_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.getSchema_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
ThriftHive.getSchema_result(Schema, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
ThriftHive.getSchema_result(ThriftHive.getSchema_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
Performs a deep copy on other.
ThriftHive.getSchema_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getThriftSchema_args - Class in org.apache.hadoop.hive.service
 
ThriftHive.getThriftSchema_args() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
ThriftHive.getThriftSchema_args(ThriftHive.getThriftSchema_args) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
Performs a deep copy on other.
ThriftHive.getThriftSchema_args._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.getThriftSchema_result - Class in org.apache.hadoop.hive.service
 
ThriftHive.getThriftSchema_result() - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
ThriftHive.getThriftSchema_result(Schema, HiveServerException) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
ThriftHive.getThriftSchema_result(ThriftHive.getThriftSchema_result) - Constructor for class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
Performs a deep copy on other.
ThriftHive.getThriftSchema_result._Fields - Enum in org.apache.hadoop.hive.service
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHive.Iface - Interface in org.apache.hadoop.hive.service
 
ThriftHive.Processor - 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_index_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_index_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
ThriftHiveMetastore.add_index_args(Index, Table) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
ThriftHiveMetastore.add_index_args(ThriftHiveMetastore.add_index_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
Performs a deep copy on other.
ThriftHiveMetastore.add_index_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_index_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_index_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
ThriftHiveMetastore.add_index_result(Index, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
ThriftHiveMetastore.add_index_result(ThriftHiveMetastore.add_index_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
Performs a deep copy on other.
ThriftHiveMetastore.add_index_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
ThriftHiveMetastore.add_partition_args(Partition) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
ThriftHiveMetastore.add_partition_args(ThriftHiveMetastore.add_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.add_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.add_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.add_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
ThriftHiveMetastore.add_partition_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
ThriftHiveMetastore.add_partition_result(ThriftHiveMetastore.add_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.add_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_database_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_database_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
ThriftHiveMetastore.alter_database_args(String, Database) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
ThriftHiveMetastore.alter_database_args(ThriftHiveMetastore.alter_database_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_database_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_database_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_database_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
ThriftHiveMetastore.alter_database_result(MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
ThriftHiveMetastore.alter_database_result(ThriftHiveMetastore.alter_database_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_database_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_index_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_index_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
ThriftHiveMetastore.alter_index_args(String, String, String, Index) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
ThriftHiveMetastore.alter_index_args(ThriftHiveMetastore.alter_index_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_index_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_index_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_index_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
ThriftHiveMetastore.alter_index_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
ThriftHiveMetastore.alter_index_result(ThriftHiveMetastore.alter_index_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_index_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
ThriftHiveMetastore.alter_partition_args(String, String, Partition) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
ThriftHiveMetastore.alter_partition_args(ThriftHiveMetastore.alter_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
ThriftHiveMetastore.alter_partition_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
ThriftHiveMetastore.alter_partition_result(ThriftHiveMetastore.alter_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_table_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_table_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
ThriftHiveMetastore.alter_table_args(String, String, Table) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
ThriftHiveMetastore.alter_table_args(ThriftHiveMetastore.alter_table_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
Performs a deep copy on other.
ThriftHiveMetastore.alter_table_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.alter_table_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.alter_table_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
ThriftHiveMetastore.alter_table_result(InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
ThriftHiveMetastore.alter_table_result(ThriftHiveMetastore.alter_table_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
Performs a deep copy on other.
ThriftHiveMetastore.alter_table_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
ThriftHiveMetastore.append_partition_args(String, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
ThriftHiveMetastore.append_partition_args(ThriftHiveMetastore.append_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
ThriftHiveMetastore.append_partition_by_name_args(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
ThriftHiveMetastore.append_partition_by_name_args(ThriftHiveMetastore.append_partition_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
ThriftHiveMetastore.append_partition_by_name_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
ThriftHiveMetastore.append_partition_by_name_result(ThriftHiveMetastore.append_partition_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.append_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.append_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
ThriftHiveMetastore.append_partition_result(Partition, InvalidObjectException, AlreadyExistsException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
ThriftHiveMetastore.append_partition_result(ThriftHiveMetastore.append_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.append_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.AsyncClient - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
 
ThriftHiveMetastore.AsyncClient.add_index_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_index_call(Index, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_index_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_index_call
 
ThriftHiveMetastore.AsyncClient.add_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.add_partition_call(Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.add_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_call
 
ThriftHiveMetastore.AsyncClient.alter_database_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_database_call(String, Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_database_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_database_call
 
ThriftHiveMetastore.AsyncClient.alter_index_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_index_call(String, String, String, Index, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_index_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_index_call
 
ThriftHiveMetastore.AsyncClient.alter_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_partition_call(String, String, Partition, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_call
 
ThriftHiveMetastore.AsyncClient.alter_table_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.alter_table_call(String, String, Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.alter_table_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_call
 
ThriftHiveMetastore.AsyncClient.append_partition_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.append_partition_by_name_call(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_call
 
ThriftHiveMetastore.AsyncClient.append_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.append_partition_call(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.append_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_call
 
ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call
 
ThriftHiveMetastore.AsyncClient.create_database_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_database_call(Database, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_database_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_database_call
 
ThriftHiveMetastore.AsyncClient.create_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_role_call(Role, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_role_call
 
ThriftHiveMetastore.AsyncClient.create_table_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_table_call(Table, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_table_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_call
 
ThriftHiveMetastore.AsyncClient.create_type_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.create_type_call(Type, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.create_type_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_type_call
 
ThriftHiveMetastore.AsyncClient.drop_database_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_database_call(String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_database_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_database_call
 
ThriftHiveMetastore.AsyncClient.drop_index_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_index_by_name_call(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_index_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_index_by_name_call
 
ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call(String, String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call
 
ThriftHiveMetastore.AsyncClient.drop_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_partition_call(String, String, List<String>, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_call
 
ThriftHiveMetastore.AsyncClient.drop_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_role_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_role_call
 
ThriftHiveMetastore.AsyncClient.drop_table_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_table_call(String, String, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_table_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_call
 
ThriftHiveMetastore.AsyncClient.drop_type_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.drop_type_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.drop_type_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_type_call
 
ThriftHiveMetastore.AsyncClient.Factory - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.Factory
 
ThriftHiveMetastore.AsyncClient.get_all_databases_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_all_databases_call(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_databases_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_databases_call
 
ThriftHiveMetastore.AsyncClient.get_all_tables_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_all_tables_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_all_tables_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_tables_call
 
ThriftHiveMetastore.AsyncClient.get_config_value_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_config_value_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_config_value_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_config_value_call
 
ThriftHiveMetastore.AsyncClient.get_database_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_database_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_database_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_database_call
 
ThriftHiveMetastore.AsyncClient.get_databases_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_databases_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_databases_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_databases_call
 
ThriftHiveMetastore.AsyncClient.get_delegation_token_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_delegation_token_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_call
 
ThriftHiveMetastore.AsyncClient.get_delegation_token_with_signature_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_delegation_token_with_signature_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_delegation_token_with_signature_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_with_signature_call
 
ThriftHiveMetastore.AsyncClient.get_fields_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_fields_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_fields_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_call
 
ThriftHiveMetastore.AsyncClient.get_index_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_index_by_name_call(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_by_name_call
 
ThriftHiveMetastore.AsyncClient.get_index_names_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_index_names_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_index_names_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_names_call
 
ThriftHiveMetastore.AsyncClient.get_indexes_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_indexes_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_indexes_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_indexes_call
 
ThriftHiveMetastore.AsyncClient.get_partition_by_name_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_by_name_call(String, String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_by_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_by_name_call
 
ThriftHiveMetastore.AsyncClient.get_partition_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_call(String, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_call
 
ThriftHiveMetastore.AsyncClient.get_partition_names_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_names_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_call
 
ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call
 
ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call(String, String, List<String>, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call(String, String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_call(String, String, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_ps_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_ps_call(String, String, List<String>, short, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call(String, String, List<String>, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call
 
ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call(String, String, short, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call
 
ThriftHiveMetastore.AsyncClient.get_privilege_set_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_privilege_set_call(HiveObjectRef, String, List<String>, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_privilege_set_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_privilege_set_call
 
ThriftHiveMetastore.AsyncClient.get_role_names_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_role_names_call(AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_role_names_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_names_call
 
ThriftHiveMetastore.AsyncClient.get_schema_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_schema_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_schema_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_call
 
ThriftHiveMetastore.AsyncClient.get_table_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_table_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_table_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_call
 
ThriftHiveMetastore.AsyncClient.get_tables_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_tables_call(String, String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_tables_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_tables_call
 
ThriftHiveMetastore.AsyncClient.get_type_all_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_type_all_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_all_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_all_call
 
ThriftHiveMetastore.AsyncClient.get_type_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.get_type_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_type_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_call
 
ThriftHiveMetastore.AsyncClient.grant_privileges_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.grant_privileges_call(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_privileges_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_privileges_call
 
ThriftHiveMetastore.AsyncClient.grant_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.grant_role_call(String, String, PrincipalType, String, PrincipalType, boolean, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.grant_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_role_call
 
ThriftHiveMetastore.AsyncClient.list_privileges_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.list_privileges_call(String, PrincipalType, HiveObjectRef, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_privileges_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_privileges_call
 
ThriftHiveMetastore.AsyncClient.list_roles_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.list_roles_call(String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.list_roles_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_roles_call
 
ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call
 
ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call
 
ThriftHiveMetastore.AsyncClient.renew_delegation_token_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.renew_delegation_token_call(String, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.renew_delegation_token_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.renew_delegation_token_call
 
ThriftHiveMetastore.AsyncClient.revoke_privileges_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.revoke_privileges_call(PrivilegeBag, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_privileges_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_privileges_call
 
ThriftHiveMetastore.AsyncClient.revoke_role_call - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.AsyncClient.revoke_role_call(String, String, PrincipalType, AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.revoke_role_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_role_call
 
ThriftHiveMetastore.AsyncIface - Interface in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.cancel_delegation_token_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.cancel_delegation_token_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
ThriftHiveMetastore.cancel_delegation_token_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
ThriftHiveMetastore.cancel_delegation_token_args(ThriftHiveMetastore.cancel_delegation_token_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
Performs a deep copy on other.
ThriftHiveMetastore.cancel_delegation_token_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.cancel_delegation_token_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.cancel_delegation_token_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
ThriftHiveMetastore.cancel_delegation_token_result(MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
ThriftHiveMetastore.cancel_delegation_token_result(ThriftHiveMetastore.cancel_delegation_token_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
Performs a deep copy on other.
ThriftHiveMetastore.cancel_delegation_token_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.Client - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Client(TProtocol) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
ThriftHiveMetastore.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client
 
ThriftHiveMetastore.Client.Factory - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Client.Factory() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Client.Factory
 
ThriftHiveMetastore.create_database_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_database_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
ThriftHiveMetastore.create_database_args(Database) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
ThriftHiveMetastore.create_database_args(ThriftHiveMetastore.create_database_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
Performs a deep copy on other.
ThriftHiveMetastore.create_database_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_database_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_database_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
ThriftHiveMetastore.create_database_result(AlreadyExistsException, InvalidObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
ThriftHiveMetastore.create_database_result(ThriftHiveMetastore.create_database_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
Performs a deep copy on other.
ThriftHiveMetastore.create_database_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
ThriftHiveMetastore.create_role_args(Role) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
ThriftHiveMetastore.create_role_args(ThriftHiveMetastore.create_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
Performs a deep copy on other.
ThriftHiveMetastore.create_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
ThriftHiveMetastore.create_role_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
ThriftHiveMetastore.create_role_result(ThriftHiveMetastore.create_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
Performs a deep copy on other.
ThriftHiveMetastore.create_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_table_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_table_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
ThriftHiveMetastore.create_table_args(Table) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
ThriftHiveMetastore.create_table_args(ThriftHiveMetastore.create_table_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
Performs a deep copy on other.
ThriftHiveMetastore.create_table_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_table_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_table_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
ThriftHiveMetastore.create_table_result(AlreadyExistsException, InvalidObjectException, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
ThriftHiveMetastore.create_table_result(ThriftHiveMetastore.create_table_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
Performs a deep copy on other.
ThriftHiveMetastore.create_table_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_type_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_type_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
ThriftHiveMetastore.create_type_args(Type) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
 
ThriftHiveMetastore.create_type_args(ThriftHiveMetastore.create_type_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args
Performs a deep copy on other.
ThriftHiveMetastore.create_type_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.create_type_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.create_type_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
ThriftHiveMetastore.create_type_result(boolean, AlreadyExistsException, InvalidObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
ThriftHiveMetastore.create_type_result(ThriftHiveMetastore.create_type_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
Performs a deep copy on other.
ThriftHiveMetastore.create_type_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_database_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_database_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
ThriftHiveMetastore.drop_database_args(String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
ThriftHiveMetastore.drop_database_args(ThriftHiveMetastore.drop_database_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_database_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_database_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_database_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
ThriftHiveMetastore.drop_database_result(NoSuchObjectException, InvalidOperationException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
ThriftHiveMetastore.drop_database_result(ThriftHiveMetastore.drop_database_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_database_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_index_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_index_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
ThriftHiveMetastore.drop_index_by_name_args(String, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
ThriftHiveMetastore.drop_index_by_name_args(ThriftHiveMetastore.drop_index_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_index_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_index_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_index_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
ThriftHiveMetastore.drop_index_by_name_result(boolean, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
ThriftHiveMetastore.drop_index_by_name_result(ThriftHiveMetastore.drop_index_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_index_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
ThriftHiveMetastore.drop_partition_args(String, String, List<String>, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
ThriftHiveMetastore.drop_partition_args(ThriftHiveMetastore.drop_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
ThriftHiveMetastore.drop_partition_by_name_args(String, String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
ThriftHiveMetastore.drop_partition_by_name_args(ThriftHiveMetastore.drop_partition_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
ThriftHiveMetastore.drop_partition_by_name_result(boolean, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
ThriftHiveMetastore.drop_partition_by_name_result(ThriftHiveMetastore.drop_partition_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
ThriftHiveMetastore.drop_partition_result(boolean, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
ThriftHiveMetastore.drop_partition_result(ThriftHiveMetastore.drop_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
ThriftHiveMetastore.drop_role_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
ThriftHiveMetastore.drop_role_args(ThriftHiveMetastore.drop_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
ThriftHiveMetastore.drop_role_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
ThriftHiveMetastore.drop_role_result(ThriftHiveMetastore.drop_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_table_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_table_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
ThriftHiveMetastore.drop_table_args(String, String, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
ThriftHiveMetastore.drop_table_args(ThriftHiveMetastore.drop_table_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_table_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_table_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_table_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
ThriftHiveMetastore.drop_table_result(NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
ThriftHiveMetastore.drop_table_result(ThriftHiveMetastore.drop_table_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_table_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_type_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_type_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
ThriftHiveMetastore.drop_type_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
 
ThriftHiveMetastore.drop_type_args(ThriftHiveMetastore.drop_type_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args
Performs a deep copy on other.
ThriftHiveMetastore.drop_type_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.drop_type_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.drop_type_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
ThriftHiveMetastore.drop_type_result(boolean, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
ThriftHiveMetastore.drop_type_result(ThriftHiveMetastore.drop_type_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
Performs a deep copy on other.
ThriftHiveMetastore.drop_type_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_all_databases_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_all_databases_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
 
ThriftHiveMetastore.get_all_databases_args(ThriftHiveMetastore.get_all_databases_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args
Performs a deep copy on other.
ThriftHiveMetastore.get_all_databases_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_all_databases_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_all_databases_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
ThriftHiveMetastore.get_all_databases_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
ThriftHiveMetastore.get_all_databases_result(ThriftHiveMetastore.get_all_databases_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
Performs a deep copy on other.
ThriftHiveMetastore.get_all_databases_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_all_tables_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_all_tables_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
ThriftHiveMetastore.get_all_tables_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
ThriftHiveMetastore.get_all_tables_args(ThriftHiveMetastore.get_all_tables_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
Performs a deep copy on other.
ThriftHiveMetastore.get_all_tables_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_all_tables_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_all_tables_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
ThriftHiveMetastore.get_all_tables_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
ThriftHiveMetastore.get_all_tables_result(ThriftHiveMetastore.get_all_tables_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
Performs a deep copy on other.
ThriftHiveMetastore.get_all_tables_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_config_value_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_config_value_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
ThriftHiveMetastore.get_config_value_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
ThriftHiveMetastore.get_config_value_args(ThriftHiveMetastore.get_config_value_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
Performs a deep copy on other.
ThriftHiveMetastore.get_config_value_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_config_value_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_config_value_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
ThriftHiveMetastore.get_config_value_result(String, ConfigValSecurityException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
ThriftHiveMetastore.get_config_value_result(ThriftHiveMetastore.get_config_value_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
Performs a deep copy on other.
ThriftHiveMetastore.get_config_value_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_database_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_database_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
ThriftHiveMetastore.get_database_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
ThriftHiveMetastore.get_database_args(ThriftHiveMetastore.get_database_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
Performs a deep copy on other.
ThriftHiveMetastore.get_database_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_database_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_database_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
ThriftHiveMetastore.get_database_result(Database, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
ThriftHiveMetastore.get_database_result(ThriftHiveMetastore.get_database_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
Performs a deep copy on other.
ThriftHiveMetastore.get_database_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_databases_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_databases_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
ThriftHiveMetastore.get_databases_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
ThriftHiveMetastore.get_databases_args(ThriftHiveMetastore.get_databases_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
Performs a deep copy on other.
ThriftHiveMetastore.get_databases_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_databases_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_databases_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
ThriftHiveMetastore.get_databases_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
ThriftHiveMetastore.get_databases_result(ThriftHiveMetastore.get_databases_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
Performs a deep copy on other.
ThriftHiveMetastore.get_databases_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_delegation_token_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_delegation_token_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
ThriftHiveMetastore.get_delegation_token_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
ThriftHiveMetastore.get_delegation_token_args(ThriftHiveMetastore.get_delegation_token_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
Performs a deep copy on other.
ThriftHiveMetastore.get_delegation_token_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_delegation_token_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_delegation_token_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
ThriftHiveMetastore.get_delegation_token_result(String, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
ThriftHiveMetastore.get_delegation_token_result(ThriftHiveMetastore.get_delegation_token_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
Performs a deep copy on other.
ThriftHiveMetastore.get_delegation_token_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_delegation_token_with_signature_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_delegation_token_with_signature_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
ThriftHiveMetastore.get_delegation_token_with_signature_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
ThriftHiveMetastore.get_delegation_token_with_signature_args(ThriftHiveMetastore.get_delegation_token_with_signature_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
Performs a deep copy on other.
ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_delegation_token_with_signature_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_delegation_token_with_signature_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
ThriftHiveMetastore.get_delegation_token_with_signature_result(String, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
 
ThriftHiveMetastore.get_delegation_token_with_signature_result(ThriftHiveMetastore.get_delegation_token_with_signature_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result
Performs a deep copy on other.
ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_fields_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_fields_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
ThriftHiveMetastore.get_fields_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
ThriftHiveMetastore.get_fields_args(ThriftHiveMetastore.get_fields_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
Performs a deep copy on other.
ThriftHiveMetastore.get_fields_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_fields_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_fields_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
ThriftHiveMetastore.get_fields_result(List<FieldSchema>, MetaException, UnknownTableException, UnknownDBException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
 
ThriftHiveMetastore.get_fields_result(ThriftHiveMetastore.get_fields_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result
Performs a deep copy on other.
ThriftHiveMetastore.get_fields_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_index_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_index_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
ThriftHiveMetastore.get_index_by_name_args(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
ThriftHiveMetastore.get_index_by_name_args(ThriftHiveMetastore.get_index_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.get_index_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_index_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_index_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
ThriftHiveMetastore.get_index_by_name_result(Index, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
ThriftHiveMetastore.get_index_by_name_result(ThriftHiveMetastore.get_index_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.get_index_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_index_names_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_index_names_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
ThriftHiveMetastore.get_index_names_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
ThriftHiveMetastore.get_index_names_args(ThriftHiveMetastore.get_index_names_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
Performs a deep copy on other.
ThriftHiveMetastore.get_index_names_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_index_names_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_index_names_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
ThriftHiveMetastore.get_index_names_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
ThriftHiveMetastore.get_index_names_result(ThriftHiveMetastore.get_index_names_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
Performs a deep copy on other.
ThriftHiveMetastore.get_index_names_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_indexes_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_indexes_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
ThriftHiveMetastore.get_indexes_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
ThriftHiveMetastore.get_indexes_args(ThriftHiveMetastore.get_indexes_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
Performs a deep copy on other.
ThriftHiveMetastore.get_indexes_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_indexes_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_indexes_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
ThriftHiveMetastore.get_indexes_result(List<Index>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
ThriftHiveMetastore.get_indexes_result(ThriftHiveMetastore.get_indexes_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
Performs a deep copy on other.
ThriftHiveMetastore.get_indexes_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
ThriftHiveMetastore.get_partition_args(String, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
ThriftHiveMetastore.get_partition_args(ThriftHiveMetastore.get_partition_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_by_name_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_by_name_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
ThriftHiveMetastore.get_partition_by_name_args(String, String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
ThriftHiveMetastore.get_partition_by_name_args(ThriftHiveMetastore.get_partition_by_name_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_by_name_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_by_name_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_by_name_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
ThriftHiveMetastore.get_partition_by_name_result(Partition, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
ThriftHiveMetastore.get_partition_by_name_result(ThriftHiveMetastore.get_partition_by_name_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_by_name_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_names_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_names_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
ThriftHiveMetastore.get_partition_names_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
ThriftHiveMetastore.get_partition_names_args(ThriftHiveMetastore.get_partition_names_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_names_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_names_ps_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_names_ps_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
ThriftHiveMetastore.get_partition_names_ps_args(String, String, List<String>, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
ThriftHiveMetastore.get_partition_names_ps_args(ThriftHiveMetastore.get_partition_names_ps_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_names_ps_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_names_ps_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_names_ps_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
ThriftHiveMetastore.get_partition_names_ps_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
ThriftHiveMetastore.get_partition_names_ps_result(ThriftHiveMetastore.get_partition_names_ps_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_names_ps_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_names_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_names_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
ThriftHiveMetastore.get_partition_names_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
ThriftHiveMetastore.get_partition_names_result(ThriftHiveMetastore.get_partition_names_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_names_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
ThriftHiveMetastore.get_partition_result(Partition, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
ThriftHiveMetastore.get_partition_result(ThriftHiveMetastore.get_partition_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_with_auth_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_with_auth_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
ThriftHiveMetastore.get_partition_with_auth_args(String, String, List<String>, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
ThriftHiveMetastore.get_partition_with_auth_args(ThriftHiveMetastore.get_partition_with_auth_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_with_auth_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partition_with_auth_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partition_with_auth_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
ThriftHiveMetastore.get_partition_with_auth_result(Partition, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
ThriftHiveMetastore.get_partition_with_auth_result(ThriftHiveMetastore.get_partition_with_auth_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partition_with_auth_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
ThriftHiveMetastore.get_partitions_args(String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
ThriftHiveMetastore.get_partitions_args(ThriftHiveMetastore.get_partitions_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_by_filter_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_by_filter_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
ThriftHiveMetastore.get_partitions_by_filter_args(String, String, String, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
ThriftHiveMetastore.get_partitions_by_filter_args(ThriftHiveMetastore.get_partitions_by_filter_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_by_filter_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_by_filter_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_by_filter_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
ThriftHiveMetastore.get_partitions_by_filter_result(List<Partition>, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
ThriftHiveMetastore.get_partitions_by_filter_result(ThriftHiveMetastore.get_partitions_by_filter_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_by_filter_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_ps_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_ps_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
ThriftHiveMetastore.get_partitions_ps_args(String, String, List<String>, short) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
ThriftHiveMetastore.get_partitions_ps_args(ThriftHiveMetastore.get_partitions_ps_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_ps_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_ps_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_ps_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
ThriftHiveMetastore.get_partitions_ps_result(List<Partition>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
ThriftHiveMetastore.get_partitions_ps_result(ThriftHiveMetastore.get_partitions_ps_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_ps_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_ps_with_auth_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_ps_with_auth_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
ThriftHiveMetastore.get_partitions_ps_with_auth_args(String, String, List<String>, short, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
ThriftHiveMetastore.get_partitions_ps_with_auth_args(ThriftHiveMetastore.get_partitions_ps_with_auth_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_ps_with_auth_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_ps_with_auth_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
ThriftHiveMetastore.get_partitions_ps_with_auth_result(List<Partition>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
ThriftHiveMetastore.get_partitions_ps_with_auth_result(ThriftHiveMetastore.get_partitions_ps_with_auth_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
ThriftHiveMetastore.get_partitions_result(List<Partition>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
ThriftHiveMetastore.get_partitions_result(ThriftHiveMetastore.get_partitions_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_with_auth_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_with_auth_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
ThriftHiveMetastore.get_partitions_with_auth_args(String, String, short, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
ThriftHiveMetastore.get_partitions_with_auth_args(ThriftHiveMetastore.get_partitions_with_auth_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_with_auth_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_partitions_with_auth_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_partitions_with_auth_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
ThriftHiveMetastore.get_partitions_with_auth_result(List<Partition>, NoSuchObjectException, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
ThriftHiveMetastore.get_partitions_with_auth_result(ThriftHiveMetastore.get_partitions_with_auth_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
Performs a deep copy on other.
ThriftHiveMetastore.get_partitions_with_auth_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_privilege_set_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_privilege_set_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
ThriftHiveMetastore.get_privilege_set_args(HiveObjectRef, String, List<String>) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
ThriftHiveMetastore.get_privilege_set_args(ThriftHiveMetastore.get_privilege_set_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
Performs a deep copy on other.
ThriftHiveMetastore.get_privilege_set_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_privilege_set_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_privilege_set_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
ThriftHiveMetastore.get_privilege_set_result(PrincipalPrivilegeSet, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
ThriftHiveMetastore.get_privilege_set_result(ThriftHiveMetastore.get_privilege_set_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
Performs a deep copy on other.
ThriftHiveMetastore.get_privilege_set_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_role_names_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_role_names_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
ThriftHiveMetastore.get_role_names_args(ThriftHiveMetastore.get_role_names_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
Performs a deep copy on other.
ThriftHiveMetastore.get_role_names_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_role_names_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_role_names_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
ThriftHiveMetastore.get_role_names_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
ThriftHiveMetastore.get_role_names_result(ThriftHiveMetastore.get_role_names_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
Performs a deep copy on other.
ThriftHiveMetastore.get_role_names_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_schema_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_schema_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
ThriftHiveMetastore.get_schema_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
ThriftHiveMetastore.get_schema_args(ThriftHiveMetastore.get_schema_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
Performs a deep copy on other.
ThriftHiveMetastore.get_schema_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_schema_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_schema_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
ThriftHiveMetastore.get_schema_result(List<FieldSchema>, MetaException, UnknownTableException, UnknownDBException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
ThriftHiveMetastore.get_schema_result(ThriftHiveMetastore.get_schema_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
Performs a deep copy on other.
ThriftHiveMetastore.get_schema_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
ThriftHiveMetastore.get_table_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
ThriftHiveMetastore.get_table_args(ThriftHiveMetastore.get_table_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
Performs a deep copy on other.
ThriftHiveMetastore.get_table_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_table_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_table_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
ThriftHiveMetastore.get_table_result(Table, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
ThriftHiveMetastore.get_table_result(ThriftHiveMetastore.get_table_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
Performs a deep copy on other.
ThriftHiveMetastore.get_table_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_tables_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_tables_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
ThriftHiveMetastore.get_tables_args(String, String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
ThriftHiveMetastore.get_tables_args(ThriftHiveMetastore.get_tables_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
Performs a deep copy on other.
ThriftHiveMetastore.get_tables_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_tables_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_tables_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
ThriftHiveMetastore.get_tables_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
ThriftHiveMetastore.get_tables_result(ThriftHiveMetastore.get_tables_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
Performs a deep copy on other.
ThriftHiveMetastore.get_tables_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_type_all_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_type_all_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
ThriftHiveMetastore.get_type_all_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
ThriftHiveMetastore.get_type_all_args(ThriftHiveMetastore.get_type_all_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
Performs a deep copy on other.
ThriftHiveMetastore.get_type_all_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_type_all_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_type_all_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
ThriftHiveMetastore.get_type_all_result(Map<String, Type>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
 
ThriftHiveMetastore.get_type_all_result(ThriftHiveMetastore.get_type_all_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result
Performs a deep copy on other.
ThriftHiveMetastore.get_type_all_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_type_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_type_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
ThriftHiveMetastore.get_type_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
ThriftHiveMetastore.get_type_args(ThriftHiveMetastore.get_type_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
Performs a deep copy on other.
ThriftHiveMetastore.get_type_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.get_type_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.get_type_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
ThriftHiveMetastore.get_type_result(Type, MetaException, NoSuchObjectException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
ThriftHiveMetastore.get_type_result(ThriftHiveMetastore.get_type_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
Performs a deep copy on other.
ThriftHiveMetastore.get_type_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_privileges_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_privileges_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
ThriftHiveMetastore.grant_privileges_args(PrivilegeBag) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
ThriftHiveMetastore.grant_privileges_args(ThriftHiveMetastore.grant_privileges_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
Performs a deep copy on other.
ThriftHiveMetastore.grant_privileges_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_privileges_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_privileges_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
ThriftHiveMetastore.grant_privileges_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
ThriftHiveMetastore.grant_privileges_result(ThriftHiveMetastore.grant_privileges_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
Performs a deep copy on other.
ThriftHiveMetastore.grant_privileges_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
ThriftHiveMetastore.grant_role_args(String, String, PrincipalType, String, PrincipalType, boolean) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
ThriftHiveMetastore.grant_role_args(ThriftHiveMetastore.grant_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
Performs a deep copy on other.
ThriftHiveMetastore.grant_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.grant_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.grant_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
ThriftHiveMetastore.grant_role_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
ThriftHiveMetastore.grant_role_result(ThriftHiveMetastore.grant_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
Performs a deep copy on other.
ThriftHiveMetastore.grant_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.Iface - Interface in org.apache.hadoop.hive.metastore.api
This interface is live.
ThriftHiveMetastore.list_privileges_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.list_privileges_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
ThriftHiveMetastore.list_privileges_args(String, PrincipalType, HiveObjectRef) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
ThriftHiveMetastore.list_privileges_args(ThriftHiveMetastore.list_privileges_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
Performs a deep copy on other.
ThriftHiveMetastore.list_privileges_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.list_privileges_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.list_privileges_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
ThriftHiveMetastore.list_privileges_result(List<HiveObjectPrivilege>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
ThriftHiveMetastore.list_privileges_result(ThriftHiveMetastore.list_privileges_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
Performs a deep copy on other.
ThriftHiveMetastore.list_privileges_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.list_roles_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.list_roles_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
ThriftHiveMetastore.list_roles_args(String, PrincipalType) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
ThriftHiveMetastore.list_roles_args(ThriftHiveMetastore.list_roles_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
Performs a deep copy on other.
ThriftHiveMetastore.list_roles_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.list_roles_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.list_roles_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
ThriftHiveMetastore.list_roles_result(List<Role>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
ThriftHiveMetastore.list_roles_result(ThriftHiveMetastore.list_roles_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
Performs a deep copy on other.
ThriftHiveMetastore.list_roles_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_to_spec_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_to_spec_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
ThriftHiveMetastore.partition_name_to_spec_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
ThriftHiveMetastore.partition_name_to_spec_args(ThriftHiveMetastore.partition_name_to_spec_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_to_spec_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_to_spec_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_to_spec_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
ThriftHiveMetastore.partition_name_to_spec_result(Map<String, String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
ThriftHiveMetastore.partition_name_to_spec_result(ThriftHiveMetastore.partition_name_to_spec_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_to_spec_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_to_vals_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_to_vals_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
ThriftHiveMetastore.partition_name_to_vals_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
ThriftHiveMetastore.partition_name_to_vals_args(ThriftHiveMetastore.partition_name_to_vals_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_to_vals_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.partition_name_to_vals_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.partition_name_to_vals_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
ThriftHiveMetastore.partition_name_to_vals_result(List<String>, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
ThriftHiveMetastore.partition_name_to_vals_result(ThriftHiveMetastore.partition_name_to_vals_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
Performs a deep copy on other.
ThriftHiveMetastore.partition_name_to_vals_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.Processor - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.Processor(ThriftHiveMetastore.Iface) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Processor
 
ThriftHiveMetastore.renew_delegation_token_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.renew_delegation_token_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
ThriftHiveMetastore.renew_delegation_token_args(String) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
ThriftHiveMetastore.renew_delegation_token_args(ThriftHiveMetastore.renew_delegation_token_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
Performs a deep copy on other.
ThriftHiveMetastore.renew_delegation_token_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.renew_delegation_token_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.renew_delegation_token_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
ThriftHiveMetastore.renew_delegation_token_result(long, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
ThriftHiveMetastore.renew_delegation_token_result(ThriftHiveMetastore.renew_delegation_token_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
Performs a deep copy on other.
ThriftHiveMetastore.renew_delegation_token_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.revoke_privileges_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.revoke_privileges_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
ThriftHiveMetastore.revoke_privileges_args(PrivilegeBag) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
ThriftHiveMetastore.revoke_privileges_args(ThriftHiveMetastore.revoke_privileges_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
Performs a deep copy on other.
ThriftHiveMetastore.revoke_privileges_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.revoke_privileges_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.revoke_privileges_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
ThriftHiveMetastore.revoke_privileges_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
ThriftHiveMetastore.revoke_privileges_result(ThriftHiveMetastore.revoke_privileges_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
Performs a deep copy on other.
ThriftHiveMetastore.revoke_privileges_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.revoke_role_args - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.revoke_role_args() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
ThriftHiveMetastore.revoke_role_args(String, String, PrincipalType) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
ThriftHiveMetastore.revoke_role_args(ThriftHiveMetastore.revoke_role_args) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
Performs a deep copy on other.
ThriftHiveMetastore.revoke_role_args._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftHiveMetastore.revoke_role_result - Class in org.apache.hadoop.hive.metastore.api
 
ThriftHiveMetastore.revoke_role_result() - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
ThriftHiveMetastore.revoke_role_result(boolean, MetaException) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
ThriftHiveMetastore.revoke_role_result(ThriftHiveMetastore.revoke_role_result) - Constructor for class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
Performs a deep copy on other.
ThriftHiveMetastore.revoke_role_result._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
thriftReaderFname - Static variable in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
thriftRWParams - Static variable in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
ThriftTestObj - Class in org.apache.hadoop.hive.serde.test
 
ThriftTestObj() - Constructor for class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
ThriftTestObj(int, String, List<InnerStruct>) - Constructor for class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
ThriftTestObj(ThriftTestObj) - Constructor for class org.apache.hadoop.hive.serde.test.ThriftTestObj
Performs a deep copy on other.
ThriftTestObj._Fields - Enum in org.apache.hadoop.hive.serde.test
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
thriftWriterFname - Static variable in class org.apache.hadoop.hive.serde2.thrift.TReflectionUtils
 
Throttle - Class in org.apache.hadoop.hive.ql.exec
Intelligence to make clients wait if the cluster is in a bad state.
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
 
timeTakenCntr - Static variable in class org.apache.hadoop.hive.ql.exec.Operator
 
TINYINT_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
toBinaryString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
toJdbcTableType(String) - Static method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
Translate hive table types into jdbc table types.
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_ALTERDATABASE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERDATABASE_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERINDEX_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERINDEX_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERINDEX_REBUILD - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERINDEX_REBUILD - 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_ALTERPARTS_PROTECTMODE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_ALTERPARTS_PROTECTMODE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_ARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_CHANGECOL_AFTER_POSITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_CHANGECOL_AFTER_POSITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_CLUSTER_SORT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_CLUSTER_SORT - 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_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_FILEFORMAT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_LOCATION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_PARTITION - 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_RENAMECOL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_RENAMECOL - 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_ALTERTABLE_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_TOUCH - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERTABLE_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERTABLE_UNARCHIVE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ALTERVIEW_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ALTERVIEW_PROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ANALYZE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ANALYZE - 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_COLTYPELIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_COLTYPELIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
tok_const - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_cpp_include - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_cpp_namespace - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
tok_cpp_type - Static variable in interface org.apache.hadoop.hive.serde2.dynamic_type.thrift_grammarConstants
RegularExpression Id.
TOK_CREATEDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CREATEDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_CREATEINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CREATEINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEINDEX_INDEXTBLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CREATEINDEX_INDEXTBLNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_CREATEROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CREATEROLE - 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_CREATEVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_CREATEVIEW - 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_DATABASECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DATABASECOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DATABASEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DATABASEPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_DBPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DBPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DEFERRED_REBUILDINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DEFERRED_REBUILDINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DESCDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DESCDATABASE - 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_DISABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DISABLE - 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_DROPDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DROPDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_DROPINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DROPINDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_DROPROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DROPROLE - 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_DROPVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_DROPVIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_ENABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ENABLE - 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_FILEFORMAT_GENERIC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_FILEFORMAT_GENERIC - 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_FUNCTIONSTAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_FUNCTIONSTAR - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GRANT_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_GRANT_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GRANT_WITH_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_GRANT_WITH_OPTION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_GROUP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_GROUP - 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_HAVING - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_HAVING - 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_HOLD_DDLTIME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_HOLD_DDLTIME - 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_IFEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_IFEXISTS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_INDEXCOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_INDEXCOMMENT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INDEXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_INDEXPROPERTIES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_INDEXPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_INDEXPROPLIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_LATERAL_VIEW - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_LATERAL_VIEW - 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_LEFTSEMIJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_LEFTSEMIJOIN - 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_LOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_LOCKTABLE - 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_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_NO_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_OFFLINE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_OFFLINE - 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_PRINCIPAL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRINCIPAL_NAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_ALL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_ALTER_DATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_ALTER_METADATA - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_CREATE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_DROP - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_INDEX - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_LOCK - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_OBJECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_OBJECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_OBJECT_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_OBJECT_COL - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_SELECT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIV_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIV_SHOW_DATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIVILEGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIVILEGE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_PRIVILEGE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_PRIVILEGE_LIST - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_READONLY - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_RECORDREADER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_RECORDWRITER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_RECORDWRITER - 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_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_REVOKE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_REVOKE_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_REVOKE_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_ROLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_ROLE - 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_SHOW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOW_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_ROLE_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOW_ROLE_GRANT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOW_TABLESTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOW_TABLESTATUS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWDATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOWDATABASES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_SHOWINDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOWINDEXES - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_SHOWLOCKS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SHOWLOCKS - 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_STORAGEHANDLER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_STORAGEHANDLER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_STREAMTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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 class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_STRUCT - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
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_SWITCHDATABASE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_SWITCHDATABASE - 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_TABALIAS - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABALIAS - 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_TABLE_PARTITION - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABLE_PARTITION - 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_TABNAME - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABNAME - 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_TABSRC - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_TABSRC - 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_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_UNIONTYPE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_UNIQUEJOIN - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_UNLOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_UNLOCKTABLE - Static variable in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TOK_USER - Static variable in class org.apache.hadoop.hive.ql.parse.HiveLexer
 
TOK_USER - 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
 
topObj() - Method in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator.IntermediateObject
 
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 exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
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.HiveObjectPrivilege
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
toString() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
toString() - Method in 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.PrincipalPrivilegeSet
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
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_index_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_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_index_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_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_all_databases_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.ThriftHiveMetastore.grant_privileges_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
toString() - Method in class org.apache.hadoop.hive.metastore.api.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.metastore.ProtectMode
 
toString() - Method in class org.apache.hadoop.hive.ql.exec.ColumnInfo
Returns the string representation of the ColumnInfo.
toString() - Method in class org.apache.hadoop.hive.ql.exec.RowSchema
 
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.index.IndexSearchCondition
 
toString() - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
toString() - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Prints this obejct as a string.
toString() - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
toString() - Method in class org.apache.hadoop.hive.ql.io.RCFile.Reader
Returns the name of the file.
toString() - Method in class org.apache.hadoop.hive.ql.lockmgr.HiveLockObject.HiveLockObjectData
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.CheckResult.PartitionResult
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.Dimension
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.Partition
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.Sample
 
toString() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
toString() - Method in class org.apache.hadoop.hive.ql.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.api.Adjacency
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeConstantDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeFieldDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.ExprNodeGenericFuncDesc
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.FetchWork
 
toString() - Method in class org.apache.hadoop.hive.ql.plan.MapredLocalWork.BucketMapJoinContext
 
toString() - Method in enum org.apache.hadoop.hive.ql.plan.RoleDDLDesc.RoleOperation
 
toString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
toString() - Method in class org.apache.hadoop.hive.ql.security.authorization.Privilege
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFExplode
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFJSONTuple
 
toString() - Method in class org.apache.hadoop.hive.ql.udf.generic.GenericUDTFParseUrlTuple
 
toString() - Method in class org.apache.hadoop.hive.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.lazybinary.LazyBinaryUtils.RecordInfo
 
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.StandardUnionObjectInspector.StandardUnion
 
toString() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StandardUnionObjectInspector
 
toString() - Method in class org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
 
toString() - Method in class org.apache.hadoop.hive.serde2.TestSerDe
 
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.getQueryPlan_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
toString() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
toString() - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
 
TOTAL_SIZE - Static variable in class org.apache.hadoop.hive.ql.stats.StatsSetupConst
The name of the statistic Row Count to be published or gathered.
totalSz - Variable in class org.apache.hadoop.hive.ql.exec.CommonJoinOperator
 
totalSz - Variable in class org.apache.hadoop.hive.ql.exec.HashTableSinkOperator
 
totalTime - Variable in class org.apache.hadoop.hive.ql.exec.Operator
 
toTempPath(Path) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
toTempPath(String) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
Given a path, convert to a temporary path.
toThriftJSONString() - Method in class org.apache.hadoop.hive.ql.QueryPlan
 
toXML() - Method in class org.apache.hadoop.hive.ql.plan.MapredWork
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.BucketMapJoinOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPruner
Transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.GroupByOptimizer
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.JoinReorder
Transform the query tree.
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.lineage.Generator
 
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.pcr.PartitionConditionRemover
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.ppr.PartitionPruner
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.ReduceSinkDeDuplication
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SamplePruner
 
transform(ParseContext) - Method in class org.apache.hadoop.hive.ql.optimizer.SortedMergeBucketMapJoinOptimizer
 
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
 
translateSearchConditions(List<IndexSearchCondition>) - Method in class org.apache.hadoop.hive.ql.index.IndexPredicateAnalyzer
Translates search conditions back to ExprNodeDesc form (as a left-deep conjunction).
transportTokenizer - Variable in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
The transport stream is tokenized on the row separator.
TReflectionUtils - Class in org.apache.hadoop.hive.serde2.thrift
TReflectionUtils.
trfmClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
TServerSocketKeepAlive - Class in org.apache.hadoop.hive.metastore
TServerSocketKeepAlive - like TServerSocket, but will enable keepalive for accepted sockets.
TServerSocketKeepAlive(int) - Constructor for class org.apache.hadoop.hive.metastore.TServerSocketKeepAlive
 
tsk - Variable in class org.apache.hadoop.hive.ql.exec.TaskRunner
 
Type - Class in org.apache.hadoop.hive.metastore.api
 
Type() - Constructor for class org.apache.hadoop.hive.metastore.api.Type
 
Type(String) - Constructor for class org.apache.hadoop.hive.metastore.api.Type
 
Type(Type) - Constructor for class org.apache.hadoop.hive.metastore.api.Type
Performs a deep copy on other.
type() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
Type._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.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.
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.
TypeInfoUtils - Class in 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.
UDAFEvaluator - Interface in org.apache.hadoop.hive.ql.exec
Interface that encapsulates the evaluation logic of a UDAF.
UDAFEvaluatorResolver - Interface in org.apache.hadoop.hive.ql.exec
The UDF Method resolver interface.
UDAFPercentile - Class in org.apache.hadoop.hive.ql.udf
UDAF for calculating the percentile values.
UDAFPercentile() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile
 
UDAFPercentile.MyComparator - Class in org.apache.hadoop.hive.ql.udf
A comparator to sort the entries in order.
UDAFPercentile.MyComparator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile.MyComparator
 
UDAFPercentile.PercentileLongArrayEvaluator - Class in org.apache.hadoop.hive.ql.udf
The evaluator for percentile computation based on long for an array of percentiles.
UDAFPercentile.PercentileLongArrayEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongArrayEvaluator
 
UDAFPercentile.PercentileLongEvaluator - Class in org.apache.hadoop.hive.ql.udf
The evaluator for percentile computation based on long.
UDAFPercentile.PercentileLongEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile.PercentileLongEvaluator
 
UDAFPercentile.State - Class in org.apache.hadoop.hive.ql.udf
A state class to store intermediate aggregation results.
UDAFPercentile.State() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFPercentile.State
 
UDAFTestMax - Class in org.apache.hadoop.hive.ql.udf
UDAFTestMax.
UDAFTestMax() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFTestMax
 
UDAFTestMax.MaxDoubleEvaluator - Class in org.apache.hadoop.hive.ql.udf
MaxDoubleEvaluator.
UDAFTestMax.MaxDoubleEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxDoubleEvaluator
 
UDAFTestMax.MaxFloatEvaluator - Class in org.apache.hadoop.hive.ql.udf
MaxFloatEvaluator.
UDAFTestMax.MaxFloatEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxFloatEvaluator
 
UDAFTestMax.MaxIntEvaluator - Class in org.apache.hadoop.hive.ql.udf
MaxIntEvaluator.
UDAFTestMax.MaxIntEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxIntEvaluator
 
UDAFTestMax.MaxLongEvaluator - Class in org.apache.hadoop.hive.ql.udf
MaxLongEvaluator.
UDAFTestMax.MaxLongEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxLongEvaluator
 
UDAFTestMax.MaxShortEvaluator - Class in org.apache.hadoop.hive.ql.udf
MaxShortEvaluator.
UDAFTestMax.MaxShortEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxShortEvaluator
 
UDAFTestMax.MaxStringEvaluator - Class in org.apache.hadoop.hive.ql.udf
MaxStringEvaluator.
UDAFTestMax.MaxStringEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFTestMax.MaxStringEvaluator
 
UDAFWrongArgLengthForTestCase - Class in org.apache.hadoop.hive.ql.udf
UDAFWrongArgLengthForTestCase.
UDAFWrongArgLengthForTestCase() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase
 
UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator - Class in org.apache.hadoop.hive.ql.udf
UDAFWrongArgLengthForTestCaseEvaluator.
UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator() - Constructor for class org.apache.hadoop.hive.ql.udf.UDAFWrongArgLengthForTestCase.UDAFWrongArgLengthForTestCaseEvaluator
 
UDF - Class in org.apache.hadoop.hive.ql.exec
A User-defined function (UDF) for the use with Hive.
UDF() - Constructor for class org.apache.hadoop.hive.ql.exec.UDF
The constructor.
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.
UDFAbs() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAbs
 
UDFAcos - Class in org.apache.hadoop.hive.ql.udf
UDFAcos.
UDFAcos() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAcos
 
UDFArgumentException - Exception in org.apache.hadoop.hive.ql.exec
exception class, thrown when udf argument have something wrong.
UDFArgumentException() - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
UDFArgumentException(String) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
UDFArgumentException(Throwable) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
 
UDFArgumentException(String, Class<?>, List<TypeInfo>, List<Method>) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentException
Constructor.
UDFArgumentLengthException - Exception in org.apache.hadoop.hive.ql.exec
exception class, thrown when udf arguments have wrong length.
UDFArgumentLengthException(String) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentLengthException
 
UDFArgumentTypeException - Exception in org.apache.hadoop.hive.ql.exec
exception class, thrown when udf arguments have wrong types.
UDFArgumentTypeException() - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentTypeException
 
UDFArgumentTypeException(int, String) - Constructor for exception org.apache.hadoop.hive.ql.exec.UDFArgumentTypeException
 
UDFAscii - Class in org.apache.hadoop.hive.ql.udf
UDFAscii.
UDFAscii() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAscii
 
UDFAsin - Class in org.apache.hadoop.hive.ql.udf
UDFAsin.
UDFAsin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAsin
 
UDFAtan - Class in org.apache.hadoop.hive.ql.udf
 
UDFAtan() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFAtan
 
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.
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.
UDFBin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFBin
 
UDFCeil - Class in org.apache.hadoop.hive.ql.udf
UDFCeil.
UDFCeil() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFCeil
 
UDFConcat - Class in org.apache.hadoop.hive.ql.udf
UDFConcat.
UDFConcat() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFConcat
 
UDFConv - Class in org.apache.hadoop.hive.ql.udf
UDFConv.
UDFConv() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFConv
 
UDFCos - Class in org.apache.hadoop.hive.ql.udf
UDFCos.
UDFCos() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFCos
 
UDFDate - Class in org.apache.hadoop.hive.ql.udf
UDFDate.
UDFDate() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDate
 
UDFDateAdd - Class in org.apache.hadoop.hive.ql.udf
UDFDateAdd.
UDFDateAdd() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDateAdd
 
UDFDateDiff - Class in org.apache.hadoop.hive.ql.udf
UDFDateDiff.
UDFDateDiff() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDateDiff
 
UDFDateSub - Class in org.apache.hadoop.hive.ql.udf
UDFDateSub.
UDFDateSub() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDateSub
 
UDFDayOfMonth - Class in org.apache.hadoop.hive.ql.udf
UDFDayOfMonth.
UDFDayOfMonth() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDayOfMonth
 
UDFDegrees - Class in org.apache.hadoop.hive.ql.udf
 
UDFDegrees() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFDegrees
 
UDFE - Class in org.apache.hadoop.hive.ql.udf
 
UDFE() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFE
 
UDFExp - Class in org.apache.hadoop.hive.ql.udf
UDFExp.
UDFExp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFExp
 
UDFFindInSet - Class in org.apache.hadoop.hive.ql.udf
UDFFindInSet.
UDFFindInSet() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFFindInSet
 
UDFFloor - Class in org.apache.hadoop.hive.ql.udf
UDFFloor.
UDFFloor() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFFloor
 
UDFFromUnixTime - Class in org.apache.hadoop.hive.ql.udf
UDFFromUnixTime.
UDFFromUnixTime() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFFromUnixTime
 
UDFHex - Class in org.apache.hadoop.hive.ql.udf
UDFHex.
UDFHex() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFHex
 
UDFHour - Class in org.apache.hadoop.hive.ql.udf
UDFHour.
UDFHour() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFHour
 
UDFJson - Class in org.apache.hadoop.hive.ql.udf
UDFJson.
UDFJson() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFJson
 
UDFLength - Class in org.apache.hadoop.hive.ql.udf
UDFLength.
UDFLength() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLength
 
UDFLike - Class in org.apache.hadoop.hive.ql.udf
UDFLike.
UDFLike() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLike
 
UDFLn - Class in org.apache.hadoop.hive.ql.udf
UDFLn.
UDFLn() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLn
 
UDFLog - Class in org.apache.hadoop.hive.ql.udf
UDFLog.
UDFLog() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog
 
UDFLog10 - Class in org.apache.hadoop.hive.ql.udf
UDFLog10.
UDFLog10() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog10
 
UDFLog2 - Class in org.apache.hadoop.hive.ql.udf
UDFLog2.
UDFLog2() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLog2
 
UDFLower - Class in org.apache.hadoop.hive.ql.udf
UDFLower.
UDFLower() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLower
 
UDFLpad - Class in org.apache.hadoop.hive.ql.udf
UDFLpad.
UDFLpad() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFLpad
 
UDFLTrim - Class in org.apache.hadoop.hive.ql.udf
UDFLTrim.
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.
UDFMinute - Class in org.apache.hadoop.hive.ql.udf
UDFMinute.
UDFMinute() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFMinute
 
UDFMonth - Class in org.apache.hadoop.hive.ql.udf
UDFMonth.
UDFMonth() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFMonth
 
UDFOPBitAnd - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitAnd.
UDFOPBitAnd() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitAnd
 
UDFOPBitNot - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitNot.
UDFOPBitNot() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitNot
 
UDFOPBitOr - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitOr.
UDFOPBitOr() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitOr
 
UDFOPBitXor - Class in org.apache.hadoop.hive.ql.udf
UDFOPBitXor.
UDFOPBitXor() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPBitXor
 
UDFOPDivide - Class in org.apache.hadoop.hive.ql.udf
UDFOPDivide.
UDFOPDivide() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPDivide
 
UDFOPLongDivide - Class in org.apache.hadoop.hive.ql.udf
UDFOPLongDivide.
UDFOPLongDivide() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPLongDivide
 
UDFOPMinus - Class in org.apache.hadoop.hive.ql.udf
UDFOPMinus.
UDFOPMinus() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPMinus
 
UDFOPMod - Class in org.apache.hadoop.hive.ql.udf
UDFOPMod.
UDFOPMod() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPMod
 
UDFOPMultiply - Class in org.apache.hadoop.hive.ql.udf
UDFOPMultiply.
UDFOPMultiply() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPMultiply
 
UDFOPNegative - Class in org.apache.hadoop.hive.ql.udf
UDFOPNegative.
UDFOPNegative() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFOPNegative
 
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.
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
 
UDFPI - Class in org.apache.hadoop.hive.ql.udf
 
UDFPI() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFPI
 
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.
UDFPower() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFPower
 
UDFRadians - Class in org.apache.hadoop.hive.ql.udf
 
UDFRadians() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRadians
 
UDFRand - Class in org.apache.hadoop.hive.ql.udf
UDFRand.
UDFRand() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRand
 
UDFRegExp - Class in org.apache.hadoop.hive.ql.udf
UDFRegExp.
UDFRegExp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRegExp
 
UDFRegExpExtract - Class in org.apache.hadoop.hive.ql.udf
UDF to extract a specific group identified by a java regex.
UDFRegExpExtract() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRegExpExtract
 
UDFRegExpReplace - Class in org.apache.hadoop.hive.ql.udf
UDFRegExpReplace.
UDFRegExpReplace() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRegExpReplace
 
UDFRepeat - Class in org.apache.hadoop.hive.ql.udf
UDFRepeat.
UDFRepeat() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRepeat
 
UDFReverse - Class in org.apache.hadoop.hive.ql.udf
UDFReverse.
UDFReverse() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFReverse
 
UDFRound - Class in org.apache.hadoop.hive.ql.udf
UDFRound.
UDFRound() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRound
 
UDFRpad - Class in org.apache.hadoop.hive.ql.udf
UDFRpad.
UDFRpad() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRpad
 
UDFRTrim - Class in org.apache.hadoop.hive.ql.udf
UDFRTrim.
UDFRTrim() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFRTrim
 
UDFSecond - Class in org.apache.hadoop.hive.ql.udf
UDFSecond.
UDFSecond() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSecond
 
UDFSign - Class in org.apache.hadoop.hive.ql.udf
 
UDFSign() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSign
 
UDFSin - Class in org.apache.hadoop.hive.ql.udf
UDFSin.
UDFSin() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSin
 
UDFSpace - Class in org.apache.hadoop.hive.ql.udf
UDFSpace.
UDFSpace() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSpace
 
UDFSqrt - Class in org.apache.hadoop.hive.ql.udf
Implementation of the SQRT UDF found in many databases.
UDFSqrt() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSqrt
 
UDFSubstr - Class in org.apache.hadoop.hive.ql.udf
UDFSubstr.
UDFSubstr() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFSubstr
 
UDFTan - Class in org.apache.hadoop.hive.ql.udf
 
UDFTan() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFTan
 
UDFTestErrorOnFalse - Class in org.apache.hadoop.hive.ql.udf
A UDF for testing, which throws RuntimeException if the length of a string.
UDFTestErrorOnFalse() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFTestErrorOnFalse
 
UDFTestLength - Class in org.apache.hadoop.hive.ql.udf
A UDF for testing, which evaluates the length of a string.
UDFTestLength() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFTestLength
 
UDFTestLength2 - Class in org.apache.hadoop.hive.ql.udf
A UDF for testing, which evaluates the length of a string.
UDFTestLength2() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFTestLength2
 
UDFToBoolean - Class in org.apache.hadoop.hive.ql.udf
UDFToBoolean.
UDFToBoolean() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToBoolean
 
UDFToByte - Class in org.apache.hadoop.hive.ql.udf
UDFToByte.
UDFToByte() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToByte
 
UDFToDate - Class in org.apache.hadoop.hive.ql.udf
UDFToDate.
UDFToDate() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToDate
 
UDFToDouble - Class in org.apache.hadoop.hive.ql.udf
UDFToDouble.
UDFToDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToDouble
 
UDFToFloat - Class in org.apache.hadoop.hive.ql.udf
UDFToFloat.
UDFToFloat() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToFloat
 
UDFToInteger - Class in org.apache.hadoop.hive.ql.udf
UDFToInteger.
UDFToInteger() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToInteger
 
UDFToLong - Class in org.apache.hadoop.hive.ql.udf
UDFToLong.
UDFToLong() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToLong
 
UDFToShort - Class in org.apache.hadoop.hive.ql.udf
UDFToShort.
UDFToShort() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToShort
 
UDFToString - Class in org.apache.hadoop.hive.ql.udf
UDFToString.
UDFToString() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFToString
 
UDFTrim - Class in org.apache.hadoop.hive.ql.udf
UDFTrim.
UDFTrim() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFTrim
 
UDFType - Annotation Type in org.apache.hadoop.hive.ql.udf
UDFType.
UDFUnhex - Class in org.apache.hadoop.hive.ql.udf
UDFUnhex.
UDFUnhex() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFUnhex
 
UDFUnixTimeStamp - Class in org.apache.hadoop.hive.ql.udf
UDFUnixTimeStamp.
UDFUnixTimeStamp() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFUnixTimeStamp
 
UDFUpper - Class in org.apache.hadoop.hive.ql.udf
UDFUpper.
UDFUpper() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFUpper
 
UDFWeekOfYear - Class in org.apache.hadoop.hive.ql.udf
UDFWeekOfYear.
UDFWeekOfYear() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFWeekOfYear
 
UDFXPathBoolean - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathBoolean() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathBoolean
 
UDFXPathDouble - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathDouble() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathDouble
 
UDFXPathFloat - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathFloat() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathFloat
 
UDFXPathInteger - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathInteger() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathInteger
 
UDFXPathLong - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathLong() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathLong
 
UDFXPathShort - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathShort() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathShort
 
UDFXPathString - Class in org.apache.hadoop.hive.ql.udf.xml
 
UDFXPathString() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathString
 
UDFXPathUtil - Class in org.apache.hadoop.hive.ql.udf.xml
Utility class for all XPath UDFs.
UDFXPathUtil() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil
 
UDFXPathUtil.ReusableStringReader - Class in org.apache.hadoop.hive.ql.udf.xml
Reusable, non-threadsafe version of StringReader.
UDFXPathUtil.ReusableStringReader() - Constructor for class org.apache.hadoop.hive.ql.udf.xml.UDFXPathUtil.ReusableStringReader
 
UDFYear - Class in org.apache.hadoop.hive.ql.udf
UDFYear.
UDFYear() - Constructor for class org.apache.hadoop.hive.ql.udf.UDFYear
 
UDTFCollector - Class in org.apache.hadoop.hive.ql.udf.generic
UDTFCollector collects data from a GenericUDTF and passes the data to a UDTFOperator.
UDTFCollector(UDTFOperator) - Constructor for class org.apache.hadoop.hive.ql.udf.generic.UDTFCollector
 
UDTFDesc - Class in org.apache.hadoop.hive.ql.plan
All member variables should have a setters and getters of the form get and set or else they won't be recreated properly at run time.
UDTFDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
UDTFDesc(GenericUDTF) - Constructor for class org.apache.hadoop.hive.ql.plan.UDTFDesc
 
UDTFOperator - Class in org.apache.hadoop.hive.ql.exec
UDTFOperator.
UDTFOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.UDTFOperator
 
unCheckedGet(int) - Method in class org.apache.hadoop.hive.serde2.columnar.BytesRefArrayWritable
Gets the BytesRefWritable at the specified position without checking.
UNDERSCORE_INT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hive.serde2.proto.test.Complexpb.IntString
 
unescapeIdentifier(String) - Static method in class org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer
Remove the encapsulating "`" pair from the identifier.
unescapePathName(String) - Static method in class org.apache.hadoop.hive.common.FileUtils
 
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
 
UNION_TYPE_NAME - Static variable in class org.apache.hadoop.hive.serde.Constants
 
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
 
UnionObject - Interface in org.apache.hadoop.hive.serde2.objectinspector
The UnionObject.
UnionObjectInspector - Interface in org.apache.hadoop.hive.serde2.objectinspector
UnionObjectInspector works on union data that is stored as UnionObject.
UnionOperator - Class in org.apache.hadoop.hive.ql.exec
Union Operator Just forwards.
UnionOperator() - Constructor for class org.apache.hadoop.hive.ql.exec.UnionOperator
 
UnionProcContext - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
UnionProcContext.
UnionProcContext() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext
 
UnionProcContext.UnionParseContext - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
UnionParseContext.
UnionProcContext.UnionParseContext(int) - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcContext.UnionParseContext
 
UnionProcessor - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Implementation of the union processor.
UnionProcessor() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcessor
empty constructor.
UnionProcFactory - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Operator factory for union processing.
UnionProcFactory.MapJoinUnion - Class in org.apache.hadoop.hive.ql.optimizer.unionproc
Map-join subquery followed by Union.
UnionProcFactory.MapJoinUnion() - Constructor for class org.apache.hadoop.hive.ql.optimizer.unionproc.UnionProcFactory.MapJoinUnion
 
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
MyField.
UnionStructObjectInspector.MyField(int, StructField) - Constructor for class org.apache.hadoop.hive.serde2.objectinspector.UnionStructObjectInspector.MyField
 
unionType() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
UnionTypeInfo - Class in org.apache.hadoop.hive.serde2.typeinfo
UnionTypeInfo represents the TypeInfo of an union.
UnionTypeInfo() - Constructor for class org.apache.hadoop.hive.serde2.typeinfo.UnionTypeInfo
For java serialization use only.
UNIQUE_JOIN - Static variable in class org.apache.hadoop.hive.ql.plan.JoinDesc
 
uniqueJoinExpr() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
uniqueJoinSource() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
uniqueJoinToken() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
UnknownDBException - Exception in org.apache.hadoop.hive.metastore.api
 
UnknownDBException() - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
UnknownDBException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownDBException
 
UnknownDBException(UnknownDBException) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownDBException
Performs a deep copy on other.
UnknownDBException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UnknownTableException - Exception in org.apache.hadoop.hive.metastore.api
 
UnknownTableException() - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
UnknownTableException(String) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownTableException
 
UnknownTableException(UnknownTableException) - Constructor for exception org.apache.hadoop.hive.metastore.api.UnknownTableException
Performs a deep copy on other.
UnknownTableException._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
unknownTypeEntry - Static variable in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils
 
unknownTypeInfo - Static variable in class org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory
 
unlock(HiveLock) - Method in interface org.apache.hadoop.hive.ql.lockmgr.HiveLockManager
 
unlock(HiveLock) - Method in class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
unlockStatement() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
UnlockTableDesc - Class in org.apache.hadoop.hive.ql.plan
UnlockTableDesc.
UnlockTableDesc() - Constructor for class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
UnlockTableDesc(String, Map<String, String>) - Constructor for class org.apache.hadoop.hive.ql.plan.UnlockTableDesc
 
unparseIdentifier(String) - Static method in class org.apache.hadoop.hive.ql.metadata.HiveUtils
Regenerate an identifier as part of unparsing it back to SQL text.
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
 
unsetAdjacencyList() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
unsetAdjacencyType() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
unsetAint() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetAString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetBase_tbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
unsetBucketCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetChildren() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
unsetCol() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
unsetCols() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetColumnName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
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.Index
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
unsetCreateTime() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetDatabase() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args
 
unsetDataLocation() - Method in class org.apache.hadoop.hive.ql.metadata.Table
 
unsetDb() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
unsetDb_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetDbName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
unsetDbname() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
unsetDefaultValue() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
unsetDeferredRebuild() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
unsetDeleteData() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
unsetDescription() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetDone() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetErrorCode() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
unsetEx() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
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
 
unsetFilter() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
unsetGrant_option() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetGrantInfo() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
unsetGrantOption() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetGrantor() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetGrantorType() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetGroup_names() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
unsetGroupPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
unsetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
unsetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
unsetHiveObject() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
unsetIdx_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
unsetIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
unsetIndex_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
unsetIndex_table() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
unsetIndexHandlerClass() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetIndexName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetIndexTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetInputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetLastAccessTime() - Method in class org.apache.hadoop.hive.metastore.api.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
 
unsetLocationUri() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetLString() - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
unsetMapTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
unsetMax_indexes() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetMax_parts() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_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.ConfigValSecurityException
 
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.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_config_value_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args
 
unsetName() - Method in class org.apache.hadoop.hive.metastore.api.Type
 
unsetNew_idx() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
unsetNew_index() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args
 
unsetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
unsetNew_part() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
unsetNew_tbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args
 
unsetNode() - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
unsetNodeType() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
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_index_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
unsetO1() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_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_index_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_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_index_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
unsetO2() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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_index_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
unsetO3() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_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_database_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_database_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
 
unsetObjectName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetObjectType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetOperatorAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetOperatorCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetOperatorGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetOperatorId() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetOperatorList() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetOperatorType() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetOrder() - Method in class org.apache.hadoop.hive.metastore.api.Order
 
unsetOrigTableName() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetOutputFormat() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetOwner() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetOwnerName() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.SerDeInfo
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.StorageDescriptor
 
unsetParameters() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
unsetPart_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
unsetPart_vals() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetPartitionKeys() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetPartValues() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
unsetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
unsetPattern() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
unsetPrincipal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
unsetPrincipal_type() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
unsetPrincipalName() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
unsetPrincipalType() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege
 
unsetPrivilege() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Database
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args
 
unsetPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
unsetProperties() - Method in class org.apache.hadoop.hive.metastore.api.Schema
 
unsetQueries() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
unsetQuery() - Method in class org.apache.hadoop.hive.service.ThriftHive.execute_args
 
unsetQueryAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetQueryCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetQueryId() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetQueryType() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetReduceTasks() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
unsetRenewer_kerberos_principal_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
unsetRetention() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetRole() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args
 
unsetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
unsetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
unsetRole_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
unsetRoleName() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
unsetRolePrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
unsetRoots() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetSd() - Method in class org.apache.hadoop.hive.metastore.api.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
 
unsetSQLState() - Method in exception org.apache.hadoop.hive.service.HiveServerException
 
unsetStageAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStageCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStageGraph() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetStageId() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStageList() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetStageType() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetStarted() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetState() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_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_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchAll_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchN_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.fetchOne_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
unsetSuccess() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
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.Partition
 
unsetTableName() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetTableType() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetTaskAttributes() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetTaskCounters() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetTaskId() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetTaskList() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
unsetTaskTrackers() - Method in class org.apache.hadoop.hive.service.HiveClusterStatus
 
unsetTaskType() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
unsetTbl() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
unsetTbl_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.append_partition_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetTbl_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args
 
unsetToken_signature() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
unsetToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
unsetToken_str_form() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
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
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
unsetUser_name() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
unsetUserPrivileges() - Method in class org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet
 
unsetValues() - Method in class org.apache.hadoop.hive.metastore.api.Partition
 
unsetVersion() - Method in class org.apache.hadoop.hive.metastore.api.Version
 
unsetViewExpandedText() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unsetViewOriginalText() - Method in class org.apache.hadoop.hive.metastore.api.Table
 
unwrap(Class<T>) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
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.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.
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.HiveBaseResultSet
 
updateArray(String, Array) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(String, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateAsciiStream(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBigDecimal(int, BigDecimal) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBigDecimal(String, BigDecimal) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(int, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(String, InputStream, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBinaryStream(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBlob(int, Blob) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBlob(String, Blob) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBlob(int, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBlob(String, InputStream) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBlob(int, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBlob(String, InputStream, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBoolean(int, boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBoolean(String, boolean) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateByte(int, byte) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateByte(String, byte) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBytes(int, byte[]) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateBytes(String, byte[]) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(int, Reader, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(String, Reader, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateCharacterStream(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateClob(int, Clob) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateClob(String, Clob) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateClob(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateClob(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateClob(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateClob(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateCounters(Counters) - Method in class org.apache.hadoop.hive.ql.exec.Operator
called in ExecDriver.progress periodically.
updateDate(int, Date) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateDate(String, Date) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateDouble(int, double) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateDouble(String, double) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateFloat(int, float) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateFloat(String, float) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
UpdateInputAccessTimeHook - Class in org.apache.hadoop.hive.ql.hooks
Implementation of a pre execute hook that updates the access times for all the inputs.
UpdateInputAccessTimeHook() - Constructor for class org.apache.hadoop.hive.ql.hooks.UpdateInputAccessTimeHook
 
UpdateInputAccessTimeHook.PreExec - Class in org.apache.hadoop.hive.ql.hooks
 
UpdateInputAccessTimeHook.PreExec() - Constructor for class org.apache.hadoop.hive.ql.hooks.UpdateInputAccessTimeHook.PreExec
 
updateInt(int, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateInt(String, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateIOContext() - Method in class org.apache.hadoop.hive.ql.io.HiveContextAwareRecordReader
 
UpdateLineColumn(char) - Method in class org.apache.hadoop.hive.serde2.dynamic_type.SimpleCharStream
 
updateLong(int, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateLong(String, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNCharacterStream(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNCharacterStream(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNCharacterStream(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNCharacterStream(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNClob(int, NClob) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNClob(String, NClob) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNClob(int, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNClob(String, Reader) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNClob(int, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNClob(String, Reader, long) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNString(int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNString(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNull(int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateNull(String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateObject(int, Object) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateObject(String, Object) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateObject(int, Object, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateObject(String, Object, int) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateRef(int, Ref) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateRef(String, Ref) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateRow() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateRowId(int, RowId) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateRowId(String, RowId) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updatesAreDetected(int) - Method in class org.apache.hadoop.hive.jdbc.HiveDatabaseMetaData
 
updateShort(int, short) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateShort(String, short) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateSkewJoinJobCounter(int) - Method in class org.apache.hadoop.hive.ql.exec.SkewJoinHandler
 
updateSQLXML(int, SQLXML) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateSQLXML(String, SQLXML) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateString(int, String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateString(String, String) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateTime(int, Time) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateTime(String, Time) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateTimestamp(int, Timestamp) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
updateTimestamp(String, Timestamp) - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
usage() - Static method in class org.apache.hadoop.hive.serde2.thrift_test.CreateSequenceFile
 
usesIndexTable() - Method in class org.apache.hadoop.hive.ql.index.compact.CompactIndexHandler
 
usesIndexTable() - Method in interface org.apache.hadoop.hive.ql.index.HiveIndexHandler
Determines whether this handler implements indexes by creating an index table.
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.
Utilities.CollectionPersistenceDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.CollectionPersistenceDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.CollectionPersistenceDelegate
 
Utilities.EnumDelegate - Class in org.apache.hadoop.hive.ql.exec
Java 1.5 workaround.
Utilities.EnumDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.EnumDelegate
 
Utilities.ListDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.ListDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.ListDelegate
 
Utilities.MapDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.MapDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.MapDelegate
 
Utilities.ReduceField - Enum in org.apache.hadoop.hive.ql.exec
ReduceField.
Utilities.SetDelegate - Class in org.apache.hadoop.hive.ql.exec
 
Utilities.SetDelegate() - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.SetDelegate
 
Utilities.StreamPrinter - Class in org.apache.hadoop.hive.ql.exec
StreamPrinter.
Utilities.StreamPrinter(InputStream, String, PrintStream) - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.StreamPrinter
 
Utilities.StreamStatus - Enum in org.apache.hadoop.hive.ql.exec
StreamStatus.
Utilities.Tuple<T,V> - Class in org.apache.hadoop.hive.ql.exec
Tuple.
Utilities.Tuple(T, V) - Constructor for class org.apache.hadoop.hive.ql.exec.Utilities.Tuple
 
Utils - Class in org.apache.hadoop.hive.ql.lib
Contains common utility functions to manipulate nodes, walkers etc.
Utils() - Constructor for class org.apache.hadoop.hive.ql.lib.Utils
 

V

valClass - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.AlreadyExistsException
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
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.HiveObjectPrivilege
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Index
 
validate() - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
validate() - Method in 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.PrincipalPrivilegeSet
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.Role
 
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_index_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_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_index_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_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_all_databases_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.ThriftHiveMetastore.grant_privileges_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
validate() - Method in class org.apache.hadoop.hive.metastore.api.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.ql.plan.api.Adjacency
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
validate() - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
validate() - 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.getQueryPlan_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
validate() - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
validateColNames(List<FieldSchema>) - Static method in class org.apache.hadoop.hive.metastore.MetaStoreUtils
 
validateColumnNames(List<String>, List<String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
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
 
validateInput(JobConf) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat
For backward compatibility with hadoop 0.17.
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]+".
validatePartSpec(Table, Map<String, String>) - Static method in class org.apache.hadoop.hive.ql.exec.Utilities
 
valToPaths - Variable in class org.apache.hadoop.hive.ql.exec.FileSinkOperator
 
value - Variable in class org.apache.hadoop.hive.metastore.parser.ExpressionTree.LeafNode
 
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.metastore.api.AlreadyExistsException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.LogicalOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.metastore.TableType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.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.JobCloseFeedBack.FeedBackType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.JoinOperator.SkewkeyTableCounter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.MapOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Operator.ProgressCounter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Operator.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.ScriptOperator.Counter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Task.FeedType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Utilities.ReduceField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.exec.Utilities.StreamStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.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.LineageInfo.DependencyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.hooks.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.index.HiveIndex.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.lockmgr.HiveLockMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.WalkState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec.SpecType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.parse.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.AlterIndexDesc.AlterIndexTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.AlterTableTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.ProtectModeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.AdjacencyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.OperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.StageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.api.TaskType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.ArchiveWork.ArchiveActionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.GroupByDesc.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.PlanUtils.ExpressionTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.plan.RoleDDLDesc.RoleOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.Privilege.PrivilegeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare.CompareType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.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.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.JobTrackerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Returns the enum constant of this type with the specified name.
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 method in enum org.apache.hadoop.hive.metastore.api.AlreadyExistsException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ConfigValSecurityException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Database._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.FieldSchema._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectRef._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.HiveObjectType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Index._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidObjectException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.InvalidOperationException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.MetaException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.NoSuchObjectException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Order._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Partition._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.PrincipalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeBag._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Role._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Schema._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.SerDeInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.StorageDescriptor._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Table._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_table_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_database_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_type_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_database_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_type_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_fields_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_table_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_tables_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_all_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_type_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Type._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownDBException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.UnknownTableException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.api.Version._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.LogicalOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.parser.ExpressionTree.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.metastore.TableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.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.JobCloseFeedBack.FeedBackType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.JoinOperator.SkewkeyTableCounter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.MapOperator.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Operator.ProgressCounter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Operator.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.ScriptOperator.Counter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Task.FeedType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Utilities.ReduceField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.exec.Utilities.StreamStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.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.LineageInfo.DependencyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.hooks.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.index.HiveIndex.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.lockmgr.HiveLockMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory.WalkState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer.tableSpec.SpecType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.parse.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.AlterIndexDesc.AlterIndexTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.AlterTableTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.AlterTableDesc.ProtectModeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.Adjacency._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.AdjacencyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.Graph._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.Operator._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.OperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.Query._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.QueryPlan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.Stage._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.StageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.Task._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.api.TaskType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.ArchiveWork.ArchiveActionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.GroupByDesc.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.HiveOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.PlanUtils.ExpressionTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.plan.RoleDDLDesc.RoleOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.Privilege.PrivilegeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.security.authorization.PrivilegeScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.session.SessionState.ResourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.ql.udf.generic.GenericUDFBaseCompare.CompareType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.serde.test.InnerStruct._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.serde.test.ThriftTestObj._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.serde2.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() - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.Complex._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.serde2.thrift.test.IntString._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.HiveClusterStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.HiveServerException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.JobTrackerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.execute_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchAll_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchN_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.fetchOne_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getClusterStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getSchema_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
VariableSubstitution - Class in org.apache.hadoop.hive.ql.parse
 
VariableSubstitution() - Constructor for class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
varname - Variable in enum org.apache.hadoop.hive.conf.HiveConf.ConfVars
 
varPat - Static variable in class org.apache.hadoop.hive.ql.parse.VariableSubstitution
 
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._Fields - Enum in org.apache.hadoop.hive.metastore.api
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
viewName() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
VirtualColumn - Class in org.apache.hadoop.hive.ql.metadata
 
VirtualColumn() - Constructor for class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
VirtualColumn(String, PrimitiveTypeInfo) - Constructor for class org.apache.hadoop.hive.ql.metadata.VirtualColumn
 
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.lib.TaskGraphWalker
walk the current operator and its descendants.
walk(Node) - Method in class org.apache.hadoop.hive.ql.optimizer.ColumnPruner.ColumnPrunerWalker
Walk the given operator.
walk(Node) - Method in class org.apache.hadoop.hive.ql.parse.GenMapRedWalker
Walk the given operator.
walkExprTree(String, ArrayList<Partition>, ExprNodeDesc) - Static method in class org.apache.hadoop.hive.ql.optimizer.pcr.PcrExprProcFactory
Remove partition conditions when necessary from the the expression tree.
warehouse - Static variable in class org.apache.hadoop.hive.metastore.TestHiveMetaStore
 
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
 
warningChain - Variable in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
wasNull - Variable in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
wasNull() - Method in class org.apache.hadoop.hive.jdbc.HiveBaseResultSet
 
wasNull() - Method in class org.apache.hadoop.hive.jdbc.HiveCallableStatement
 
whenExpression() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
whereClause() - Method in class org.apache.hadoop.hive.ql.parse.HiveParser
 
withOption() - 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
 
wrapProcessor(TProcessor) - Method in class org.apache.hadoop.hive.thrift.HadoopThriftAuthBridge.Server
 
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 exception org.apache.hadoop.hive.metastore.api.ConfigValSecurityException
 
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.HiveObjectPrivilege
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.HiveObjectRef
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Index
 
write(TProtocol) - Method in exception org.apache.hadoop.hive.metastore.api.IndexAlreadyExistsException
 
write(TProtocol) - Method in 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.PrincipalPrivilegeSet
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeBag
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.PrivilegeGrantInfo
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.Role
 
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_index_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_index_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.add_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_database_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_index_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.alter_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_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.append_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.cancel_delegation_token_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.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_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_table_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.create_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_index_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_index_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_table_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.drop_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_all_databases_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_databases_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_all_tables_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_config_value_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_database_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_databases_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_delegation_token_with_signature_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_index_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_index_names_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_indexes_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_by_name_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_ps_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_names_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partition_with_auth_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_by_filter_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_ps_with_auth_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_partitions_with_auth_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_privilege_set_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_role_names_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_schema_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.get_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.ThriftHiveMetastore.grant_privileges_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_privileges_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.grant_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_privileges_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.list_roles_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_spec_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.partition_name_to_vals_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.renew_delegation_token_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_privileges_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.revoke_role_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.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(Writable) - Method in interface org.apache.hadoop.hive.ql.exec.RecordWriter
 
write(Writable) - Method in class org.apache.hadoop.hive.ql.exec.TextRecordWriter
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.BucketizedHiveInputSplit
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.CombineHiveInputFormat.CombineHiveInputSplit
Writable interface.
write(K, V) - Method in class org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat.IgnoreKeyWriter
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.HiveInputFormat.HiveInputSplit
 
write(K, V) - Method in class org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat.IgnoreKeyWriter
Deprecated.  
write(DataInput, int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
Writes bytes from a DataInput directly into the buffer.
write(int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
 
write(byte[], int, int) - Method in class org.apache.hadoop.hive.ql.io.NonSyncDataOutputBuffer
 
write(DataOutput) - Method in class org.apache.hadoop.hive.ql.io.SymlinkTextInputFormat.SymlinkTextInputSplit
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Adjacency
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Graph
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Operator
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Query
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.QueryPlan
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Stage
 
write(TProtocol) - Method in class org.apache.hadoop.hive.ql.plan.api.Task
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.InnerStruct
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde.test.ThriftTestObj
 
write(byte) - Method in class org.apache.hadoop.hive.serde2.binarysortable.OutputByteBuffer
 
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(DataOutput) - Method in class org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorUtils.PrimitiveTypeEntry
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.Complex
 
write(TProtocol) - Method in class org.apache.hadoop.hive.serde2.thrift.test.IntString
 
write(TProtocol) - Method in class org.apache.hadoop.hive.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.getQueryPlan_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getQueryPlan_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getSchema_result
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_args
 
write(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.getThriftSchema_result
 
write(DataOutput) - Method in interface org.apache.hadoop.hive.shims.HadoopShims.InputSplitShim
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_index_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.add_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_database_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_index_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.alter_table_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.append_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_database_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_table_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.create_type_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_database_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_index_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_table_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.drop_type_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_databases_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_all_tables_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_config_value_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_database_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_databases_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_delegation_token_with_signature_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_fields_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_index_names_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_indexes_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_by_name_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_privilege_set_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_role_names_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_schema_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_table_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_tables_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_all_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.get_type_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_privileges_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.grant_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_privileges_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.list_roles_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.renew_delegation_token_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_privileges_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient.revoke_role_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.execute_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchAll_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchN_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.fetchOne_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getClusterStatus_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getQueryPlan_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getSchema_call
 
write_args(TProtocol) - Method in class org.apache.hadoop.hive.service.ThriftHive.AsyncClient.getThriftSchema_call
 
writeBinary(ByteBuffer) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBinary(byte[]) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBinary(byte[], int, int) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBinary(ByteBuffer) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
writeBool(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.TBinarySortableProtocol
 
writeBool(boolean) - Method in class org.apache.hadoop.hive.serde2.thrift.TCTLSeparatedProtocol
 
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() - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Only used by serialization.
WriteEntity(Table) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a table.
WriteEntity(Table, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
WriteEntity(Partition) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a partition.
WriteEntity(Partition, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
WriteEntity(DummyPartition, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
WriteEntity(String, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
Constructor for a file.
WriteEntity(String, boolean, boolean) - Constructor for class org.apache.hadoop.hive.ql.hooks.WriteEntity
 
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.persistence.AbstractMapJoinKey
 
writeExternal(ObjectOutput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinDoubleKeys
 
writeExternal(ObjectOutput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectKey
 
writeExternal(ObjectOutput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinObjectValue
 
writeExternal(ObjectOutput) - Method in class org.apache.hadoop.hive.ql.exec.persistence.MapJoinSingleKey
 
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
 
writeGrantInfo(DataOutput, PrincipalType, String, String, String, String, String, PrivilegeGrantInfo) - Static method in class org.apache.hadoop.hive.ql.exec.DDLTask
 
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
 
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
 
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
 
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
 
ZooKeeperHiveLock - Class in org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
ZooKeeperHiveLock(String, HiveLockObject, HiveLockMode) - Constructor for class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLock
 
ZooKeeperHiveLockManager - Class in org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
ZooKeeperHiveLockManager() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager
 
ZooKeeperHiveLockManager.DummyWatcher - Class in org.apache.hadoop.hive.ql.lockmgr.zookeeper
 
ZooKeeperHiveLockManager.DummyWatcher() - Constructor for class org.apache.hadoop.hive.ql.lockmgr.zookeeper.ZooKeeperHiveLockManager.DummyWatcher
 

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

Copyright © 2011 The Apache Software Foundation