| Name | Description | Type | Package | Framework |
| AbortTxnRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| AbstractBucketJoinProc | this transformation does bucket map join optimization. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| AbstractCommandHandler | An abstract implementation of CommandHandler. | Class | org.apache.hive.beeline | Apache Hive |
|
| AbstractDeserializer | Abstract class for implementing Deserializer. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| AbstractEncodingAwareSerDe | AbstractEncodingAwareSerDe aware the encoding from table properties, transform data from specified charset to UTF-8 during serialize, and | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| AbstractFileMergeOperator | Fast file merge operator for ORC and RCfile. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| AbstractFilterStringColLikeStringScalar | An abstract class for LIKE and REGEXP expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| AbstractGenericUDAFResolver | An abstract class to help facilitate existing implementations of GenericUDAFResolver to migrate towards the newly introduced | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| AbstractGenericUDFEWAHBitmapBop | An abstract class for a UDF that performs a binary operation between two EWAH-compressed bitmaps. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| AbstractGenericUDFReflect | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| AbstractHBaseKeyFactory | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| AbstractHBaseKeyPredicateDecomposer | Simple abstract class to help with creation of a HiveStoragePredicateHandler. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| AbstractIndexHandler | Abstract base class for index handlers. | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| AbstractJoinTaskDispatcher | Common iteration methods for converting joins and sort-merge joins. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| AbstractMapJoinOperator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| AbstractMapJoinTableContainer | | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| AbstractOperatorDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AbstractParquetMapInspector | | Class | org.apache.hadoop.hive.ql.io.parquet.serde | Apache Hive |
|
| AbstractPrimitiveJavaObjectInspector | An AbstractJavaPrimitiveObjectInspector for a Java object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| AbstractPrimitiveLazyObjectInspector | An AbstractPrimitiveLazyObjectInspector for a LazyPrimitive object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| AbstractPrimitiveObjectInspector | An AbstractPrimitiveObjectInspector is based on ObjectInspectorUtils. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| AbstractPrimitiveWritableObjectInspector | An AbstractWritablePrimitiveObjectInspector for a Writable object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| AbstractRowContainer | | Interface | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| AbstractSemanticAnalyzerHook | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| AbstractSerDe | Abstract class for implementing SerDe. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| AbstractSerializer | Abstract class for implementing Serializer. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| AbstractService | | Class | org.apache.hive.service | Apache Hive |
|
| AbstractSMBJoinProc | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| AbstractStorageFormatDescriptor | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| AbstractVectorDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AccumuloCompositeRowId | AccumuloCompositeKey extension of LazyStruct. | Class | org.apache.hadoop.hive.accumulo.serde | Apache Hive |
|
| AccumuloConnectionParameters | | Class | org.apache.hadoop.hive.accumulo | Apache Hive |
|
| AccumuloHiveConstants | | Class | org.apache.hadoop.hive.accumulo | Apache Hive |
|
| AccumuloHiveRow | Holds column tuples for rowID. | Class | org.apache.hadoop.hive.accumulo | Apache Hive |
|
| AccumuloPredicateHandler | Supporting operations dealing with Hive Predicate pushdown to iterators and ranges. | Class | org.apache.hadoop.hive.accumulo.predicate | Apache Hive |
|
| AccumuloRangeGenerator | | Class | org.apache.hadoop.hive.accumulo.predicate | Apache Hive |
|
| AccumuloRowIdFactory | | Interface | org.apache.hadoop.hive.accumulo.serde | Apache Hive |
|
| AccumuloRowSerializer | | Class | org.apache.hadoop.hive.accumulo.serde | Apache Hive |
|
| AccumuloSerDe | Deserialization from Accumulo to LazyAccumuloRow for Hive. | Class | org.apache.hadoop.hive.accumulo.serde | Apache Hive |
|
| AccumuloSerDeParameters | | Class | org.apache.hadoop.hive.accumulo.serde | Apache Hive |
|
| AccumuloStorageHandler | Create table mapping to Accumulo for Hive. | Class | org.apache.hadoop.hive.accumulo | Apache Hive |
|
| AcidInputFormat | The interface required for input formats that what to support ACID The goal is to provide ACID transactions to Hive. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| AcidOutputFormat | An extension for OutputFormats that want to implement ACID transactions. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| AcidUtils | Utilities that are shared by all of the ACID input and output formats. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| AddDynamicPartitions | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| AddIndexEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| AddPartitionDesc | Contains the information needed to add one or more partitions. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AddPartitionEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| AddPartitionMessage | The HCat message sent when partition(s) are added to a table. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| AddPartitionReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| AddPartitionsRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| AddPartitionsResult | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| AddResourceProcessor | AddResourceProcessor. | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| Adjacency | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| AdjacencyType | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| AggregateIndexHandler | Index handler for indexes that have aggregate functions on indexed columns. | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| AggregateStatsCache | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| AggregationDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AggrStats | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| AlreadyExistsException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| AlterDatabaseDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AlterHandler | | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| AlterIndexDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AlterIndexEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| AlterPartitionEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| AlterPartitionMessage | HCat message sent when a table is Altered. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| AlterPartitionReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| AlterTableAlterPartDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AlterTableDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AlterTableEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| AlterTableExchangePartition | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AlterTableMessage | HCat message sent when a table is Altered. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| AlterTablePartMergeFilesDesc | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| AlterTableReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| AlterTableSimpleDesc | Contains information needed to modify a partition or a tableSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AmbiguousMethodException | Exception thrown by the UDF and UDAF method resolvers in case a unique methodSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| AnnotateOpTraitsProcCtx | | Class | org.apache.hadoop.hive.ql.optimizer.metainfo.annotation | Apache Hive |
|
| AnnotateStatsProcCtx | | Class | org.apache.hadoop.hive.ql.optimizer.stats.annotation | Apache Hive |
|
| AnnotateWithOpTraits | | Class | org.apache.hadoop.hive.ql.optimizer.metainfo.annotation | Apache Hive |
|
| AnnotateWithStatistics | | Class | org.apache.hadoop.hive.ql.optimizer.stats.annotation | Apache Hive |
|
| AnnotationUtils | | Class | org.apache.hive.common.util | Apache Hive |
|
| AnonymousAuthenticationProviderImpl | This authentication provider allows any combination of username and password. | Class | org.apache.hive.service.auth | Apache Hive |
|
| AppConfig | The configuration for Templeton. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| AppMasterEventDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| AppMasterEventOperator | AppMasterEventOperator sends any rows it receives to the Tez AM. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| AppMasterEventProcessor | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ArchiveDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ArchiveUtils | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ArchiveWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ArrayWritableObjectInspector | The ArrayWritableObjectInspector will inspect an ArrayWritable, considering it as a Hive struct. | Class | org.apache.hadoop.hive.ql.io.parquet.serde | Apache Hive |
|
| ASTConverter | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| ASTErrorNode | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ASTNode | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ASTNodeOrigin | ASTNodeOrigin contains contextual information about the object from whose definition a particular ASTNode originated. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ATSHook | ATSHook sends query + plan info to Yarn App Timeline Server. | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| Attr | | Class | org.apache.hadoop.hive.common.jsonexplain.tez | Apache Hive |
|
| AuthenticationProviderFactory | This class helps select a PasswdAuthenticationProvider for a given AuthMethod. | Class | org.apache.hive.service.auth | Apache Hive |
|
| AuthorizationException | | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| AuthorizationFactory | | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| AuthorizationMetaStoreFilterHook | Metastore filter hook for filtering out the list of objects that the current authorization implementation does not allow user to see | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| AuthorizationParseUtils | | Class | org.apache.hadoop.hive.ql.parse.authorization | Apache Hive |
|
| AuthorizationPreEventListener | AuthorizationPreEventListener : A MetaStorePreEventListener that performs authorization/authentication checks on the metastore-side. | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| AuthorizationUtils | | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| AutoProgressor | 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 | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| AvgPartitionSizeBasedBigTableSelectorForAutoSMJ | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| AvroContainerInputFormat | | Class | org.apache.hadoop.hive.ql.io.avro | Apache Hive |
|
| AvroContainerOutputFormat | Write to an Avro file from a Hive process. | Class | org.apache.hadoop.hive.ql.io.avro | Apache Hive |
|
| AvroGenericRecordReader | RecordReader optimized against Avro GenericRecords that returns to record as the value of the k-v pair, as Hive requires. | Class | org.apache.hadoop.hive.ql.io.avro | Apache Hive |
|
| AvroGenericRecordWritable | Wrapper around an Avro GenericRecord. | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| AvroGenericRecordWriter | Write an Avro GenericRecord to an Avro data file. | Class | org.apache.hadoop.hive.ql.io.avro | Apache Hive |
|
| AvroHBaseValueFactory | | Class | org.apache.hadoop.hive.hbase.struct | Apache Hive |
|
| AvroLazyObjectInspector | | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| AvroObjectInspectorException | Exception for the AvroLazyObjectInspectorSee Also:Serialized Form | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| AvroObjectInspectorGenerator | An AvroObjectInspectorGenerator takes an Avro schema and creates the three data structures Hive needs to work with Avro-encoded data: | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| AvroSchemaRetriever | Retrieves the avro schema from the given source. | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| AvroSerDe | Read or write Avro data from Hive. | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| AvroSerdeException | | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| AvroSerdeUtils | Utilities useful only to the AvroSerde itself. | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| AvroStorageFormatDescriptor | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| BadParam | Missing required or badly configured paramater. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| BadSchemaException | | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| Base64TextInputFormat | FileInputFormat for base64 encoded text files. | Class | org.apache.hadoop.hive.contrib.fileformat.base64 | Apache Hive |
|
| Base64TextOutputFormat | FileOutputFormat for base64 encoded text files. | Class | org.apache.hadoop.hive.contrib.fileformat.base64 | Apache Hive |
|
| BaseCharTypeInfo | | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| BaseCharUtils | | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| BaseSemanticAnalyzer | BaseSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| BaseStructObjectInspector | | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| BaseWork | BaseWork. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| BeeLine | A console SQL shell with command completion. | Class | org.apache.hive.beeline | Apache Hive |
|
| BigTableSelectorForAutoSMJ | | Interface | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| BinaryColumnStatistics | Statistics for binary columns. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| BinaryColumnStatsData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| BinaryObjectInspector | | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| BinaryRecordReader | Read from a binary stream and treat each 1000 bytes (configurable via hive. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| BinarySortableDeserializeRead | | Class | org.apache.hadoop.hive.serde2.binarysortable.fast | Apache Hive |
|
| BinarySortableSerDe | BinarySortableSerDe can be used to write data in a way that the data can be compared byte-by-byte with the same order. | Class | org.apache.hadoop.hive.serde2.binarysortable | Apache Hive |
|
| BinarySortableSerializeWrite | | Class | org.apache.hadoop.hive.serde2.binarysortable.fast | Apache Hive |
|
| BitmapIndexHandler | Index handler for the bitmap index. | Class | org.apache.hadoop.hive.ql.index.bitmap | Apache Hive |
|
| BitmapInnerQuery | Representation of inner bitmap index SELECT query that scans bitmap index tables for a pushed predicate | Class | org.apache.hadoop.hive.ql.index.bitmap | Apache Hive |
|
| BitmapObjectInput | An ObjectInput that allows for conversion from an List of LongWritable to an EWAH-compressed bitmap. | Class | org.apache.hadoop.hive.ql.index.bitmap | Apache Hive |
|
| BitmapObjectOutput | An ObjectOutput that allows conversion from an EWAH-compressed bitmap to an List of LongWritable. | Class | org.apache.hadoop.hive.ql.index.bitmap | Apache Hive |
|
| BitmapOuterQuery | Representation of the outer query on bitmap indexes that JOINs the result of inner SELECT scans on bitmap indexes (represented in BitmapQuery objects) | Class | org.apache.hadoop.hive.ql.index.bitmap | Apache Hive |
|
| BitmapQuery | | Interface | org.apache.hadoop.hive.ql.index.bitmap | Apache Hive |
|
| BitSetCheckedAuthorizationProvider | | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| BloomFilter | BloomFilter is a probabilistic data structure for set membership check. | Class | org.apache.hive.common.util | Apache Hive |
|
| BloomFilterIO | | Class | org.apache.hadoop.hive.ql.io.filters | Apache Hive |
|
| BooleanColumnStatistics | Statistics for boolean columns. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| BooleanColumnStatsData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| BooleanObjectInspector | A BooleanObjectInspector inspects an Object representing a Boolean. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| BoundaryDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| BreakableService | This is a service that can be configured to break on any of the lifecycle events, so test the failure handling of other parts of the service | Class | org.apache.hive.service | Apache Hive |
|
| BucketingSortingCtx | This class contains the bucketing sorting context that is passed while walking the operator tree in inferring bucket/sort columns. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| BucketingSortingInferenceOptimizer | BucketingSortingInferenceOptimizer. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| BucketingSortingOpProcFactory | Operator factory for the rule processors for inferring bucketing/sorting columns. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| BucketingSortingReduceSinkOptimizer | This transformation does optimization for enforcing bucketing and sorting. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| BucketizedHiveInputFormat | BucketizedHiveInputFormat serves the similar function as hiveInputFormat but its getSplits() always group splits from one input file into one wrapper | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| BucketizedHiveInputSplit | HiveInputSplit encapsulates an InputSplit with its corresponding inputFormatClass. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| BucketizedHiveRecordReader | BucketizedHiveRecordReader is a wrapper on a list of RecordReader. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| BucketJoinProcCtx | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| BucketMapJoinContext | was inner class of MapreLocalWork. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| BucketMapJoinOptimizer | this transformation does bucket map join optimization. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| BucketMapjoinProc | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| BucketMatcher | | Interface | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| BusyException | Simple "we are busy, try again" exception. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| ByteArrayRef | ByteArrayRef stores a reference to a byte array. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| ByteObjectInspector | A ByteObjectInspector inspects an Object representing a Byte object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| BytesBytesMultiHashMap | HashMap that maps byte arrays to byte arrays with limited functionality necessary for MapJoin hash tables, with small memory overhead. | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| BytesColumnVector | This class supports string and binary data by value reference -- i. | Class | org.apache.hadoop.hive.ql.exec.vector | Apache Hive |
|
| BytesRefArrayWritable | BytesRefArrayWritable holds an array reference to BytesRefWritable, and is able to resize without recreating new array if not necessary. | Class | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| BytesRefWritable | BytesRefWritable referenced a section of byte array. | Class | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| ByteStream | Extensions to bytearrayinput/output streams. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| ByteStreamTypedSerDe | ByteStreamTypedSerDe. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| ByteWritable | Looks like this has been phased out in favor of org. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ByteWritable | This class was created before the Hadoop version of this class was available, and needs to be kept around for backward compatibility of third-party UDFs/SerDes. | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| CachingPrintStream | | Class | org.apache.hadoop.hive.common.io | Apache Hive |
|
| CalcitePlanner | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| CalciteSemanticException | Exception from SemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| CallbackFailedException | The callback failed when it tried to reach the callback URL. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| CastBooleanToCharViaLongToChar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastBooleanToStringViaLongToString | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastBooleanToVarCharViaLongToVarChar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDateToBooleanViaLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastDateToChar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDateToString | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDateToVarChar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDecimalToBoolean | Type cast decimal to booleanSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDecimalToChar | To support vectorized cast of decimal to string. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDecimalToDecimal | Cast a decimal to a decimal, accounting for precision and scale changes. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDecimalToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDecimalToLong | Type cast decimal to longSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDecimalToString | To support vectorized cast of decimal to string. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDecimalToTimestamp | Type cast decimal to timestamp. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDecimalToVarChar | To support vectorized cast of decimal to string. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDoubleToBooleanViaDoubleToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastDoubleToDecimal | Cast input double to a decimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastDoubleToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastDoubleToTimestampViaDoubleToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastLongToBooleanViaLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastLongToChar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastLongToDate | Casts a timestamp and date vector to a date vector. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastLongToDecimal | To be used to cast long and boolean to decimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastLongToString | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastLongToTimestampViaLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastLongToVarChar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastMillisecondsLongToTimestampViaLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastStringGroupToChar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastStringGroupToVarChar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastStringToDate | Casts a string vector to a date vector. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastStringToDecimal | Cast a string to a decimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastStringToIntervalDayTime | Casts a string vector to a interval day-time vector. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastStringToIntervalYearMonth | Casts a string vector to a interval year-month vector. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastTimestampToBooleanViaLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastTimestampToDecimal | To be used to cast timestamp to decimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CastTimestampToDoubleViaLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CastTimestampToLongViaLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CatchallExceptionMapper | Map all exceptions to the Jersey response. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| CharScalarConcatStringGroupCol | Vectorized instruction to concatenate a scalar to a string column and put the result in an output column. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CharScalarEqualStringGroupColumn | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CharScalarGreaterEqualStringGroupColumn | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CharScalarGreaterStringGroupColumn | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CharScalarLessEqualStringGroupColumn | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CharScalarLessStringGroupColumn | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CharScalarNotEqualStringGroupColumn | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| CharTypeInfo | | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| CheckJDOException | Check if this is a javax. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| CheckLockRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| CheckResult | Result class used by the HiveMetaStoreChecker. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| ClassicTableTypeMapping | ClassicTableTypeMapping. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| ClassNameCompleter | the completer is original provided in JLine 0. | Class | org.apache.hive.beeline | Apache Hive |
|
| Cleaner | A class to clean directories after compactions. | Class | org.apache.hadoop.hive.ql.txn.compactor | Apache Hive |
|
| CliDriver | | Class | org.apache.hadoop.hive.cli | Apache Hive |
|
| ClientStatsPublisher | | Interface | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| CLIService | | Class | org.apache.hive.service.cli | Apache Hive |
|
| CLIServiceClient | | Class | org.apache.hive.service.cli | Apache Hive |
|
| CLIServiceUtils | | Class | org.apache.hive.service.cli | Apache Hive |
|
| CliSessionState | SessionState for hive cli. | Class | org.apache.hadoop.hive.cli | Apache Hive |
|
| ClosedOrCancelledStatementException | | Class | org.apache.hive.jdbc | Apache Hive |
|
| CodecPool | A global compressor/decompressor pool used to save and reuse (possibly native) compression/decompression codecs. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| ColAndCol | Evaluate AND of two boolean columns and store result in the output boolean column. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CollectDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CollectOperator | Buffers rows emitted by other operators. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| Collector | Collector gets data from a source. | Interface | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| ColOrCol | This class performs OR expression on two input columns and stores, the boolean output in a separate output column. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| ColStatistics | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| Column | | Class | org.apache.hive.service.cli | Apache Hive |
|
| ColumnAccessAnalyzer | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ColumnAccessInfo | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ColumnarSerDe | ColumnarSerDe is used for columnar based storage supported by RCFile. | Class | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| ColumnarSerDeBase | | Class | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| ColumnarStruct | ColumnarStruct is different from LazyStruct in that ColumnarStruct's field Object get parsed at its initialize time when call | Class | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| ColumnarStructBase | | Class | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| ColumnBasedSet | | Class | org.apache.hive.service.cli | Apache Hive |
|
| ColumnDesc | A description of the column to create. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| ColumnDescriptor | | Class | org.apache.hive.service.cli | Apache Hive |
|
| ColumnEncoding | Encapsulate the encoding of values within the given column in AccumuloEnum Constant Summary | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| ColumnInfo | (the one that is used by the operator to access the column) and the type (identified by a java class). | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ColumnMapper | | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| ColumnMapping | | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| ColumnMappingFactory | | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| ColumnMappings | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| ColumnProjectionUtils | ColumnProjectionUtils. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| ColumnPruner | the current operator tree. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| ColumnPrunerProcCtx | This class implements the processor context for Column Pruner. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| ColumnPrunerProcFactory | Factory for generating the different node processors used by ColumnPruner. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| ColumnSet | | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| ColumnStatistics | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ColumnStatistics | Statistics that are available for all types of columns. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| ColumnStatisticsData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ColumnStatisticsDesc | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ColumnStatisticsObj | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ColumnStatsDesc | Contains the information needed to persist column level statisticsSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ColumnStatsSemanticAnalyzer | ColumnStatsSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ColumnStatsTask | ColumnStatsTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ColumnStatsUpdateTask | ColumnStatsUpdateTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ColumnStatsUpdateWork | ColumnStatsUpdateWork implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ColumnStatsWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ColumnTruncateMapper | | Class | org.apache.hadoop.hive.ql.io.rcfile.truncate | Apache Hive |
|
| ColumnTruncateTask | | Class | org.apache.hadoop.hive.ql.io.rcfile.truncate | Apache Hive |
|
| ColumnTruncateWork | | Class | org.apache.hadoop.hive.ql.io.rcfile.truncate | Apache Hive |
|
| ColumnValue | | Class | org.apache.hive.service.cli | Apache Hive |
|
| ColumnVector | ColumnVector contains the shared structure for the sub-types, including NULL information, and whether this vector | Class | org.apache.hadoop.hive.ql.exec.vector | Apache Hive |
|
| CombineHiveInputFormat | CombineHiveInputFormat is a parameterized InputFormat which looks at the path name and determine the correct InputFormat for that path name from | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| CombineHiveKey | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| CombineHiveRecordReader | CombineHiveRecordReader. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| Command | Interface that abstracts the notion of one atomic command to execute. | Interface | org.apache.hive.hcatalog.api.repl | Apache Hive |
|
| CommandNeedRetryException | | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| CommandProcessor | | Interface | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| CommandProcessorFactory | CommandProcessorFactory. | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| CommandProcessorResponse | Encapsulates the basic response info returned by classes the implement the CommandProcessor interface. | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| Commands | | Class | org.apache.hive.beeline | Apache Hive |
|
| CommitTxnRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| CommonCliOptions | Reusable code for Hive Cli's. | Class | org.apache.hadoop.hive.common.cli | Apache Hive |
|
| CommonJoinOperator | Join operator implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| CommonJoinResolver | | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| CommonJoinTaskDispatcher | Iterator each tasks. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| CommonMergeJoinDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CommonMergeJoinOperator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| CompactIndexHandler | | Class | org.apache.hadoop.hive.ql.index.compact | Apache Hive |
|
| CompactionInfo | Information on a possible or running compaction. | Class | org.apache.hadoop.hive.metastore.txn | Apache Hive |
|
| CompactionRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| CompactionTxnHandler | methods are not available through the thrift interface. | Class | org.apache.hadoop.hive.metastore.txn | Apache Hive |
|
| CompactionType | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| CompactorMR | Class to do compactions via an MR job. | Class | org.apache.hadoop.hive.ql.txn.compactor | Apache Hive |
|
| CompareOp | Handles different types of comparisons in hive predicates. | Interface | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| ComparisonOpMethodResolver | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| CompileProcessor | Processor allows users to build code inside a hive session, then use this code as a UDF, Serde, or even a more complex entity like an | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| CompleteBean | CompleteBean - The results of an CompleteDelegator run. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| CompleteDelegator | Complete a job. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| Complex | | Class | org.apache.hadoop.hive.serde2.thrift.test | Apache Hive |
|
| Complexpb | | Class | org.apache.hadoop.hive.serde2.proto.test | Apache Hive |
|
| CompositeAccumuloRowIdFactory | AccumuloRowIdFactory designed for injection of the AccumuloCompositeRowId to be used to generate the Accumulo rowId. | Class | org.apache.hadoop.hive.accumulo.serde | Apache Hive |
|
| CompositeHBaseKeyFactory | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| CompositePartitionSpecProxy | | Class | org.apache.hadoop.hive.metastore.partition.spec | Apache Hive |
|
| CompositeProcessor | CompositeProcessor. | Class | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| CompositeService | | Class | org.apache.hive.service | Apache Hive |
|
| CompressionCodec | | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| CompressionKind | enum CompressionKindAn enumeration that lists the generic compression algorithms that | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| CompressionUtils | This class contains methods used for the purposes of compression, this class should not be accessed from code run in Hadoop. | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| ConcurrentScheduler | Originally taken from com. | Class | org.apache.hive.testutils.junit.runners.model | Apache Hive |
|
| ConcurrentTestRunner | Originally taken from com. | Class | org.apache.hive.testutils.junit.runners | Apache Hive |
|
| ConditionalResolver | Conditional task resolution interface. | Interface | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ConditionalResolverCommonJoin | ConditionalResolverSkewJoin. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ConditionalResolverMergeFiles | Conditional task resolution interface. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ConditionalResolverSkewJoin | ConditionalResolverSkewJoin. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ConditionalTask | Conditional Task implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ConditionalWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ConfigChangeEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| ConfigurableTProtocol | An interface for TProtocols that need to have properties passed in to initialize them. | Interface | org.apache.hadoop.hive.serde2.thrift | Apache Hive |
|
| ConfigValSecurityException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| Connection | | Class | org.apache.hadoop.hive.common.jsonexplain.tez | Apache Hive |
|
| ConnectionError | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| ConnectionFailureException | Class representing exceptions resulting from connection problems between HCat client and server. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| ConstantObjectInspector | ConstantObjectInspector. | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ConstantPropagate | from root to child. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| ConstantPropagateProcCtx | This class implements the processor context for Constant Propagate. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| ConstantPropagateProcFactory | Factory for generating the different node processors used by ConstantPropagate. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| Constants | | Class | org.apache.hadoop.hive.serde | Apache Hive |
|
| ConstantVectorExpression | Constant is represented as a vector with repeating values. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| ContentSummaryInputFormat | ContentSummayInputFormat provides an interface to let the input format itself figure the content summary for a give input path. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| Context | Context for Semantic Analyzers. | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| ConversionTreeReaderFactory | Factory for creating ORC tree readers. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| ConvertJoinMapJoin | ConvertJoinMapJoin is an optimization that replaces a common join (aka shuffle join) with a map join (aka broadcast or fragment replicate | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| CookieSigner | The cookie signer generates a signature based on SHA digest and appends it to the cookie value generated at the | Class | org.apache.hive.service | Apache Hive |
|
| CopyTask | CopyTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| CopyWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CorrelationOptimizer | the paper "YSmart: Yet Another SQL-to-MapReduce Translator" (Rubao Lee, Tian Luo, Yin Huai, Fusheng Wang, Yongqiang He, and Xiaodong Zhang) | Class | org.apache.hadoop.hive.ql.optimizer.correlation | Apache Hive |
|
| CorrelationUtilities | Utilities for both CorrelationOptimizer and ReduceSinkDeDuplication. | Class | org.apache.hadoop.hive.ql.optimizer.correlation | Apache Hive |
|
| CounterStatsAggregator | | Class | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| CounterStatsAggregatorSpark | | Class | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| CounterStatsAggregatorTez | This class aggregates stats via counters and does so for Tez Tasks. | Class | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| CounterStatsPublisher | | Class | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| CreateDatabaseDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CreateDatabaseEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| CreateDatabaseMessage | HCat message sent when a Database is created in HCatalog. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| CreateDatabaseReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| CreateFunctionDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CreateIndexDesc | create index descriptorSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CreateMacroDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CreateTableAutomaticGrant | | Class | org.apache.hadoop.hive.ql.session | Apache Hive |
|
| CreateTableDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CreateTableEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| CreateTableLikeDesc | CreateTableLikeDesc. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CreateTableMessage | HCat message sent when a table is created in HCatalog. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| CreateTableReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| CreateViewDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| CrossMapEqualComparer | | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| CrossProductCheck | | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| CryptoProcessor | This class processes HADOOP commands used for HDFS encryption. | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| CuckooSetBytes | A high-performance set implementation used to support fast set membership testing, using Cuckoo hashing. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CuckooSetDouble | A high-performance set implementation used to support fast set membership testing, using Cuckoo hashing. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CuckooSetLong | A high-performance set implementation used to support fast set membership testing, using Cuckoo hashing. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| CuratorFrameworkSingleton | | Class | org.apache.hadoop.hive.ql.lockmgr.zookeeper | Apache Hive |
|
| CurrentNotificationEventId | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| CurrentRowDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| CustomAuthenticationProviderImpl | This authentication provider implements the CUSTOM authentication. | Class | org.apache.hive.service.auth | Apache Hive |
|
| CustomPartitionEdge | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| CustomPartitionVertex | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| CustomVertexConfiguration | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| DagUtils | DagUtils. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| Database | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| DatabaseDesc | A description of the database to create. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| DataCorruptErrorHeuristic | Detects the condition where there is a error with one of the input files in Conditions to check: | Class | org.apache.hadoop.hive.ql.exec.errors | Apache Hive |
|
| DataInputByteBuffer | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| DataInputInputStream | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| DataOutputOutputStream | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| DataReadMethod | Method by which input data was read. | Class | org.apache.hive.spark.client.metrics | Apache Hive |
|
| DataTransferFactory | Use this factory to get instances of HCatReader or HCatWriter at master and slave nodes. | Class | org.apache.hive.hcatalog.data.transfer | Apache Hive |
|
| DataType | | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| DataWritableReadSupport | A MapWritableReadSupport Manages the translation between Hive and Parquet | Class | org.apache.hadoop.hive.ql.io.parquet.read | Apache Hive |
|
| DataWritableRecordConverter | | Class | org.apache.hadoop.hive.ql.io.parquet.convert | Apache Hive |
|
| DataWritableWriter | DataWritableWriter is a writer that reads a ParquetWritable object and send the data to the Parquet API with the expected schema. | Class | org.apache.hadoop.hive.ql.io.parquet.write | Apache Hive |
|
| DataWritableWriteSupport | | Class | org.apache.hadoop.hive.ql.io.parquet.write | Apache Hive |
|
| Date | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| DateColAddIntervalDayTimeColumn | Generated from template ColumnArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColAddIntervalDayTimeScalar | Generated from template ColumnArithmeticScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColAddIntervalYearMonthColumn | Generated from template DateTimeColumnArithmeticIntervalColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColAddIntervalYearMonthScalar | Generated from template ColumnArithmeticScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColEqualDateScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColGreaterDateScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColGreaterEqualDateScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColLessDateScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColLessEqualDateScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColNotEqualDateScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColSubtractDateColumn | Generated from template ColumnArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColSubtractDateScalar | Generated from template ColumnArithmeticScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColSubtractIntervalDayTimeColumn | Generated from template ColumnArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColSubtractIntervalDayTimeScalar | Generated from template ColumnArithmeticScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColSubtractIntervalYearMonthColumn | Generated from template DateTimeColumnArithmeticIntervalColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColSubtractIntervalYearMonthScalar | Generated from template ColumnArithmeticScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColSubtractTimestampColumn | Generated from template ColumnArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColSubtractTimestampScalar | Generated from template ColumnArithmeticScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateColumnStatistics | Statistics for DATE columns. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| DateColumnStatsData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| DateObjectInspector | A DateObjectInspector inspects an Object representing a Date. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| DateScalarAddIntervalDayTimeColumn | Generated from template ScalarArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarAddIntervalYearMonthColumn | Generated from template DateTimeScalarArithmeticIntervalColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarEqualDateColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarGreaterDateColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarGreaterEqualDateColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarLessDateColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarLessEqualDateColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarNotEqualDateColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarSubtractDateColumn | Generated from template ScalarArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarSubtractIntervalDayTimeColumn | Generated from template ScalarArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarSubtractIntervalYearMonthColumn | Generated from template DateTimeScalarArithmeticIntervalColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateScalarSubtractTimestampColumn | Generated from template ScalarArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DateTimeMath | | Class | org.apache.hadoop.hive.ql.util | Apache Hive |
|
| DateUtils | DateUtils. | Class | org.apache.hive.common.util | Apache Hive |
|
| DateWritable | Writable equivalent of java. | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| DbLockManager | An implementation of HiveLockManager for use with DbTxnManager. | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| DbNotificationListener | An implementation of MetaStoreEventListener that stores events in the database. | Class | org.apache.hive.hcatalog.listener | Apache Hive |
|
| DBTokenStore | | Class | org.apache.hadoop.hive.thrift | Apache Hive |
|
| DbTxnManager | An implementation of HiveTxnManager that stores the transactions in the metastore database. | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| DDLDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DDLSemanticAnalyzer | DDLSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| DDLTask | DDLTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DDLWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| Deadline | This class is used to monitor long running methods in a thread. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| DeadlineException | Thrown when a long running method timeout is checked. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| Decimal | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| Decimal128 | This code was based on code from Microsoft's PolyBase. | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| Decimal128FastBuffer | | Class | org.apache.hive.common.util | Apache Hive |
|
| DecimalColAddDecimalColumn | Generated from template ColumnArithmeticColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColAddDecimalScalar | Generated from template ColumnArithmeticScalarDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColDivideDecimalColumn | Generated from template ColumnArithmeticColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColDivideDecimalScalar | Generated from template ColumnDivideScalarDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColModuloDecimalColumn | Generated from template ColumnArithmeticColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColModuloDecimalScalar | Generated from template ColumnDivideScalarDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColMultiplyDecimalColumn | Generated from template ColumnArithmeticColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColMultiplyDecimalScalar | Generated from template ColumnArithmeticScalarDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColSubtractDecimalColumn | Generated from template ColumnArithmeticColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColSubtractDecimalScalar | Generated from template ColumnArithmeticScalarDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalColumnInList | Output a boolean value indicating if a column is IN a list of constants. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| DecimalColumnStatistics | Statistics for decimal columns. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| DecimalColumnStatsData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| DecimalColumnVector | | Class | org.apache.hadoop.hive.ql.exec.vector | Apache Hive |
|
| DecimalNumDistinctValueEstimator | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| DecimalScalarAddDecimalColumn | Generated from template ScalarArithmeticColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalScalarDivideDecimalColumn | Generated from template ScalarDivideColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalScalarModuloDecimalColumn | Generated from template ScalarDivideColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalScalarMultiplyDecimalColumn | Generated from template ScalarArithmeticColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalScalarSubtractDecimalColumn | Generated from template ScalarArithmeticColumnDecimal. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DecimalToStringUnaryUDF | This is a superclass for unary decimal functions returning strings that operate directly on the input and set the output. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| DecimalTypeInfo | | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| DecimalUtil | Utility functions for vector operations on decimal values. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| DeepParquetHiveMapInspector | The DeepParquetHiveMapInspector will inspect an ArrayWritable, considering it as a Hive map. | Class | org.apache.hadoop.hive.ql.io.parquet.serde | Apache Hive |
|
| DefaultAccumuloRowIdFactory | Default implementation of the AccumuloRowIdFactory which uses the normal AccumuloRowSerializer methods to serialize the field for storage into Accumulo. | Class | org.apache.hadoop.hive.accumulo.serde | Apache Hive |
|
| DefaultBucketMatcher | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DefaultFetchFormatter | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DefaultFileAccess | versions which do not implement FileSystem. | Class | org.apache.hadoop.fs | Apache Hive |
|
| DefaultGraphWalker | base class for operator graph walker this class takes list of starting ops and walks them one by one. | Class | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| DefaultHBaseKeyFactory | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| DefaultHBaseValueFactory | | Class | org.apache.hadoop.hive.hbase.struct | Apache Hive |
|
| DefaultHCatRecord | | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| DefaultHiveAuthorizationProvider | | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| DefaultHiveMetastoreAuthorizationProvider | | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| DefaultHivePartitioner | Partition keys by their Object. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| DefaultMetaStoreFilterHookImpl | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| DefaultRuleDispatcher | Dispatches calls to relevant method in processor. | Class | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| DefaultStateProvider | | Class | org.apache.hive.hcatalog.data.transfer.state | Apache Hive |
|
| DefaultStorageHandler | DefaultStorageHandler is an implementation of HiveStorageHandler which supplies the standard defaults for all options. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| DefaultUDAFEvaluatorResolver | The default UDAF Method resolver. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DefaultUDFMethodResolver | The default UDF Method resolver. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DelegationTokenCache | | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| DelegationTokenIdentifier | A delegation token identifier that is specific to Hive. | Class | org.apache.hadoop.hive.thrift | Apache Hive |
|
| DelegationTokenSecretManager | A Hive specific delegation token secret manager. | Class | org.apache.hadoop.hive.thrift | Apache Hive |
|
| DelegationTokenSelector | | Class | org.apache.hadoop.hive.thrift | Apache Hive |
|
| DelegationTokenStore | Interface for pluggable token store that can be implemented with shared external storage for load balancing and high availability (for example using ZooKeeper). | Interface | org.apache.hadoop.hive.thrift | Apache Hive |
|
| DeleteDelegator | | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| DeleteResourceProcessor | DeleteResourceProcessor. | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| DelimitedInputWriter | Streaming Writer handles delimited input (eg. | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| DelimitedJSONSerDe | This serde can only serialize, because it is just intended for use by the FetchTask class and the TRANSFORM function. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| DemuxDesc | Demux operator descriptor implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DemuxOperator | DemuxOperator is an operator used by MapReduce Jobs optimized by CorrelationOptimizer. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DependencyCollectionTask | DependencyCollectionTask. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DependencyCollectionWork | DependencyCollectionWorkSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DependencyResolver | | Class | org.apache.hadoop.hive.ql.session | Apache Hive |
|
| DescDatabaseDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DescFunctionDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| Description | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DescTableDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| Deserializer | 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. | Interface | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| DeserializeRead | | Interface | org.apache.hadoop.hive.serde2.fast | Apache Hive |
|
| DfsProcessor | | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| DigestPrintStream | | Class | org.apache.hadoop.hive.common.io | Apache Hive |
|
| Dimension | Hive consists of a fixed, well defined set of Dimensions. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| DirectDecompressionCodec | | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| DisallowTransformHook | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| DiskRange | The sections of a file. | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| DiskRangeList | Java linked list iterator interface is convoluted, and moreover concurrent modifications of the same list by multiple iterators are impossible. | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| Dispatcher | Dispatcher interface for Operators Used in operator graph walking to dispatch process/visitor functions for operators. | Interface | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| DistinctElementsClassPath | This object represents a path as used by CLASSPATH or PATH environment variable. | Class | org.apache.hadoop.hive.ant | Apache Hive |
|
| DosToUnix | | Class | org.apache.hadoop.hive.ql.util | Apache Hive |
|
| DoubleColAddDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColAddDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColAddLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColAddLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColDivideDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColDivideDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColDivideLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColDivideLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColEqualDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColEqualDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColEqualLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColEqualLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColGreaterDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColGreaterDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColGreaterEqualDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColGreaterEqualDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColGreaterEqualLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColGreaterEqualLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColGreaterLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColGreaterLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColLessDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColLessDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColLessEqualDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColLessEqualDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColLessEqualLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColLessEqualLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColLessLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColLessLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColModuloDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColModuloDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColModuloLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColModuloLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColMultiplyDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColMultiplyDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColMultiplyLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColMultiplyLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColNotEqualDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColNotEqualDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColNotEqualLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColNotEqualLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColSubtractDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColSubtractDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColSubtractLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColSubtractLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleColumnInList | Output a boolean value indicating if a column is IN a list of constants. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| DoubleColumnStatistics | Statistics for float and double columns. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| DoubleColumnStatsData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| DoubleColumnVector | This class represents a nullable double precision floating point column vector. | Class | org.apache.hadoop.hive.ql.exec.vector | Apache Hive |
|
| DoubleColUnaryMinus | Generated from template ColumnUnaryMinus. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleCompare | Set of comparison operations over a double constant. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| DoubleNumDistinctValueEstimator | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| DoubleObjectInspector | A DoubleObjectInspector inspects an Object representing a Double. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| DoubleScalarAddDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarAddLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarDivideDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarDivideLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarEqualDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarEqualLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarEqualTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarGreaterDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarGreaterEqualDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarGreaterEqualLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarGreaterEqualTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarGreaterLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarGreaterTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarLessDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarLessEqualDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarLessEqualLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarLessEqualTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarLessLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarLessTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarModuloDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarModuloLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarMultiplyDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarMultiplyLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarNotEqualDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarNotEqualLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarNotEqualTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarSubtractDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleScalarSubtractLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| DoubleWritable | Writable for Double values. | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| Driver | | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| DriverContext | | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| DriverInfo | | Class | org.apache.hive.beeline | Apache Hive |
|
| DriverTestHook | | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| DropDatabaseCommand | | Class | org.apache.hive.hcatalog.api.repl.commands | Apache Hive |
|
| DropDatabaseDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DropDatabaseEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| DropDatabaseMessage | HCat message sent when a Database is dropped from HCatalog. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| DropDatabaseReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| DropFunctionDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DropIndexDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DropIndexEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| DropMacroDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DropPartitionCommand | | Class | org.apache.hive.hcatalog.api.repl.commands | Apache Hive |
|
| DropPartitionEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| DropPartitionMessage | HCat message sent when a partition is dropped in HCatalog. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| DropPartitionReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| DropPartitionsExpr | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| DropPartitionsRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| DropPartitionsResult | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| DropTableCommand | | Class | org.apache.hive.hcatalog.api.repl.commands | Apache Hive |
|
| DropTableDesc | TODO: this is currently used for both drop table and drop partitions. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DropTableEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| DropTableMessage | HCat message sent when a Table is dropped in HCatalog. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| DropTableReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| DummyHiveAuthorizationValidator | A no-op HiveAuthorizationValidator for use from hive cli. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| DummyPartition | A Hive Table Partition: is a fundamental storage unit within a Table. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| DummyStoreDesc | Dummy Store Desc. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DummyStoreOperator | For SortMerge joins, this is a dummy operator, which stores the row for the small table before it reaches the sort merge join operator. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| DynamicPartitionCtx | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DynamicPartitionPruner | DynamicPartitionPruner takes a list of assigned partitions at runtime (split generation) and prunes them using events generated during execution of the | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| DynamicPartitionPruningOptimization | This optimization looks for expressions of the kind "x IN (RS[n])". | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| DynamicPruningEventDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| DynamicSerDe | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeAsync | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeCommaOrSemicolon | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeConst | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeConstList | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeConstListContents | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeConstMap | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeConstMapContents | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeConstValue | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeDefinition | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeDefinitionType | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeEnum | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeEnumDef | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeEnumDefList | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeExtends | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeField | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeFieldList | DynamicSerDeFieldList. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeFieldRequiredness | DynamicSerDeFieldRequiredness. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeFieldType | DynamicSerDeFieldType. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeFieldValue | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeFlagArgs | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeFunction | DynamicSerDeFunction. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeFunctionType | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeHeader | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeHeaderList | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeInclude | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeNamespace | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeSenum | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeSenumDef | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeSenumDefList | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeService | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeSimpleNode | DynamicSerDeSimpleNode. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeStart | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeStruct | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeStructBase | DynamicSerDeStructBase. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeThrows | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeBase | DynamicSerDeTypeBase. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeBool | DynamicSerDeTypeBool. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeByte | DynamicSerDeTypeByte. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypedef | DynamicSerDeTypedef. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeDefinition | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeDouble | DynamicSerDeTypeDouble. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypei16 | DynamicSerDeTypei16. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypei32 | DynamicSerDeTypei32. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypei64 | DynamicSerDeTypei64. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeList | DynamicSerDeTypeList. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeMap | DynamicSerDeTypeMap. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeSet | DynamicSerDeTypeSet. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeTypeString | DynamicSerDeTypeString. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeUnflagArgs | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| DynamicSerDeXception | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| EmbeddedCLIServiceClient | EmbeddedCLIServiceClient. | Class | org.apache.hive.service.cli | Apache Hive |
|
| EmbeddedLockManager | shared lock manager for dedicated hive server. | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| EmbeddedThriftBinaryCLIService | EmbeddedThriftBinaryCLIService. | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| EnforceReadOnlyTables | | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| EnqueueBean | EnqueueBean - The results of a call that enqueues a Hadoop job. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| Entity | This class encapsulates an object that is being read or written to by the query. | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| EnvironmentContext | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| Equal | Wraps call to isEqual() over PrimitiveCompare instance. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| ErrorAndSolution | Immutable class for storing a possible error and a resolution suggestion. | Class | org.apache.hadoop.hive.ql.exec.errors | Apache Hive |
|
| ErrorHeuristic | Classes implementing ErrorHeuristic are able to generate a possible cause and solution for Hive jobs that have failed by examining the query, task log | Interface | org.apache.hadoop.hive.ql.exec.errors | Apache Hive |
|
| ErrorMsg | List of all error messages. | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| ErrorType | Enum type representing the various errors throws by HCat. | Class | org.apache.hive.hcatalog.common | Apache Hive |
|
| ETypeConverter | ETypeConverter is an easy way to set the converter for the right type. | Class | org.apache.hadoop.hive.ql.io.parquet.convert | Apache Hive |
|
| EventCleanerTask | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| EventRequestType | enum EventRequestTypeEnum Constant Summary | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ExecBean | ExecBean - The results of an exec call. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| ExecDriver | ExecDriver is the central class in co-ordinating execution of any map-reduce task. | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| ExecMapper | ExecMapper is the generic Map class for Hive. | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| ExecMapperContext | | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| ExecReducer | ExecReducer is the generic Reducer class for Hive. | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| ExecService | | Interface | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| ExecServiceImpl | Execute a local program. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| ExecuteStatementOperation | | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| ExecuteWithHookContext | ExecuteWithHookContext is a new interface that the Pre/Post Execute Hook can run with the HookContext. | Interface | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| EximReplicationTaskFactory | EXIMReplicationTaskFactory is an export-import based ReplicationTask. | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| EximUtil | EximUtil. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| Explain | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExplainSemanticAnalyzer | ExplainSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ExplainSQRewriteSemanticAnalyzer | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ExplainSQRewriteTask | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExplainSQRewriteWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExplainTask | ExplainTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExplainWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExplosionDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExportCommand | | Class | org.apache.hive.hcatalog.api.repl.commands | Apache Hive |
|
| ExportSemanticAnalyzer | ExportSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ExpressionTree | The Class representing the filter as a binary tree. | Class | org.apache.hadoop.hive.metastore.parser | Apache Hive |
|
| ExprNodeColumnDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExprNodeColumnEvaluator | This evaluator gets the column from the row object. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExprNodeColumnListDesc | Dummy desc only for populating TOK_ALLCOLREF and should not be used outside of TypeCheckProcFactory | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExprNodeConstantDesc | A constant expression. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExprNodeConstantEvaluator | ExprNodeConstantEvaluator. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExprNodeConverter | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| ExprNodeDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExprNodeDescUtils | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExprNodeDynamicListDesc | This expression represents a list that will be available at runtime. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExprNodeEvaluator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExprNodeEvaluatorFactory | ExprNodeEvaluatorFactory. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExprNodeEvaluatorHead | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExprNodeEvaluatorRef | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExprNodeFieldDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExprNodeFieldEvaluator | This Evaluator can evaluate s. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExprNodeGenericFuncDesc | Describes a GenericFunc node. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ExprNodeGenericFuncEvaluator | ExprNodeGenericFuncEvaluator. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ExprProcCtx | The processor context for the lineage information. | Class | org.apache.hadoop.hive.ql.optimizer.lineage | Apache Hive |
|
| ExprProcCtx | The processor context for partition pruner. | Class | org.apache.hadoop.hive.ql.optimizer.ppr | Apache Hive |
|
| ExprProcFactory | Expression processor factory for lineage. | Class | org.apache.hadoop.hive.ql.optimizer.lineage | Apache Hive |
|
| ExprProcFactory | Expression processor factory for partition pruning. | Class | org.apache.hadoop.hive.ql.optimizer.ppr | Apache Hive |
|
| ExprPrunerInfo | The processor context for partition pruner. | Class | org.apache.hadoop.hive.ql.optimizer.ppr | Apache Hive |
|
| ExprWalkerInfo | Context for Expression Walker for determining predicate pushdown candidates It contains a ExprInfo object for each expression that is processed. | Class | org.apache.hadoop.hive.ql.ppd | Apache Hive |
|
| ExprWalkerProcFactory | Expression factory for predicate pushdown processing. | Class | org.apache.hadoop.hive.ql.ppd | Apache Hive |
|
| FairSchedulerShim | | Class | org.apache.hadoop.hive.schshim | Apache Hive |
|
| FetchConverter | | Class | org.apache.hadoop.hive.common.io | Apache Hive |
|
| FetchFormatter | | Interface | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FetchOperator | FetchTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FetchOrientation | enum FetchOrientationEnum Constant Summary | Class | org.apache.hive.service.cli | Apache Hive |
|
| FetchTask | FetchTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FetchType | FetchType indicates the type of fetchResults request. | Class | org.apache.hive.service.cli | Apache Hive |
|
| FetchWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| FieldSchema | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| FileDump | A tool for printing out the file structure of ORC files. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| FileMergeDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| FileSinkDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| FileSinkOperator | File Sink operator implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FileSinkProcessor | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| FileUtils | Collection of file manipulation utilities common across Hive. | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| FilterCharColumnBetween | This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterCharColumnNotBetween | This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterCharScalarEqualStringGroupColumn | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterCharScalarGreaterEqualStringGroupColumn | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterCharScalarGreaterStringGroupColumn | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterCharScalarLessEqualStringGroupColumn | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterCharScalarLessStringGroupColumn | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterCharScalarNotEqualStringGroupColumn | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterColAndScalar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterColOrScalar | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterConstantBooleanVectorExpression | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterDateColEqualDateScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateColGreaterDateScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateColGreaterEqualDateScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateColLessDateScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateColLessEqualDateScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateColNotEqualDateScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateScalarEqualDateColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateScalarGreaterDateColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateScalarGreaterEqualDateColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateScalarLessDateColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateScalarLessEqualDateColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDateScalarNotEqualDateColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColEqualDecimalColumn | Generated from template FilterDecimalColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColEqualDecimalScalar | This is a generated class to evaluate a == comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColGreaterDecimalColumn | Generated from template FilterDecimalColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColGreaterDecimalScalar | This is a generated class to evaluate a > comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColGreaterEqualDecimalColumn | Generated from template FilterDecimalColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColGreaterEqualDecimalScalar | This is a generated class to evaluate a >= comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColLessDecimalColumn | Generated from template FilterDecimalColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColLessDecimalScalar | This is a generated class to evaluate a < comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColLessEqualDecimalColumn | Generated from template FilterDecimalColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColLessEqualDecimalScalar | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColNotEqualDecimalColumn | Generated from template FilterDecimalColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColNotEqualDecimalScalar | This is a generated class to evaluate a != comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColumnBetween | Generated from template FilterDecimalColumnBetween. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalColumnInList | Evaluate IN filter on a batch for a vector of decimals. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterDecimalColumnNotBetween | Generated from template FilterDecimalColumnBetween. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalScalarEqualDecimalColumn | This is a generated class to evaluate a == comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalScalarGreaterDecimalColumn | This is a generated class to evaluate a > comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalScalarGreaterEqualDecimalColumn | This is a generated class to evaluate a >= comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalScalarLessDecimalColumn | This is a generated class to evaluate a < comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalScalarLessEqualDecimalColumn | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDecimalScalarNotEqualDecimalColumn | This is a generated class to evaluate a != comparison on a vector of decimalSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| FilterDoubleColEqualDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColEqualDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColEqualLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColEqualLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColGreaterDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColGreaterDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColGreaterEqualDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColGreaterEqualDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColGreaterEqualLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColGreaterEqualLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColGreaterLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColGreaterLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColLessDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColLessDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColLessEqualDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColLessEqualDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColLessEqualLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColLessEqualLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColLessLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColLessLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColNotEqualDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColNotEqualDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColNotEqualLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColNotEqualLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColumnBetween | Generated from template FilterColumnBetween. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleColumnInList | Evaluate IN filter on a batch for a vector of doubles. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterDoubleColumnNotBetween | Generated from template FilterColumnBetween. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarEqualDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarEqualLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarEqualTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarGreaterDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarGreaterEqualDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarGreaterEqualLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarGreaterEqualTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarGreaterLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarGreaterTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarLessDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarLessEqualDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarLessEqualLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarLessEqualTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarLessLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarLessTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarNotEqualDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarNotEqualLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterDoubleScalarNotEqualTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterExprAndExpr | This class represents a non leaf binary operator in the expression tree. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterExprOrExpr | This class represents an Or expression. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterIntervalDayTimeColEqualIntervalDayTimeScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeColGreaterEqualIntervalDayTimeScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeColGreaterIntervalDayTimeScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeColLessEqualIntervalDayTimeScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeColLessIntervalDayTimeScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeColNotEqualIntervalDayTimeScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeScalarEqualIntervalDayTimeColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeScalarGreaterIntervalDayTimeColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeScalarLessEqualIntervalDayTimeColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeScalarLessIntervalDayTimeColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalDayTimeScalarNotEqualIntervalDayTimeColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthColEqualIntervalYearMonthScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthColGreaterEqualIntervalYearMonthScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthColGreaterIntervalYearMonthScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthColLessEqualIntervalYearMonthScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthColLessIntervalYearMonthScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthColNotEqualIntervalYearMonthScalar | Generated from template FilterDTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthScalarEqualIntervalYearMonthColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthScalarGreaterIntervalYearMonthColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthScalarLessEqualIntervalYearMonthColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthScalarLessIntervalYearMonthColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterIntervalYearMonthScalarNotEqualIntervalYearMonthColumn | Generated from template FilterDTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLexer | | Class | org.apache.hadoop.hive.metastore.parser | Apache Hive |
|
| FilterLongColEqualDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColEqualDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColEqualLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColEqualLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColGreaterDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColGreaterDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColGreaterEqualDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColGreaterEqualDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColGreaterEqualLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColGreaterEqualLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColGreaterLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColGreaterLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColLessDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColLessDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColLessEqualDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColLessEqualDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColLessEqualLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColLessEqualLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColLessLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColLessLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColNotEqualDoubleColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColNotEqualDoubleScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColNotEqualLongColumn | Generated from template FilterColumnCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColNotEqualLongScalar | Generated from template FilterColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColumnBetween | Generated from template FilterColumnBetween. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongColumnInList | Evaluate IN filter on a batch for a vector of longs. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterLongColumnNotBetween | Generated from template FilterColumnBetween. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarEqualDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarEqualLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarEqualTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarGreaterDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarGreaterEqualDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarGreaterEqualLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarGreaterEqualTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarGreaterLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarGreaterTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarLessDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarLessEqualDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarLessEqualLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarLessEqualTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarLessLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarLessTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarNotEqualDoubleColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarNotEqualLongColumn | Generated from template FilterScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterLongScalarNotEqualTimestampColumn | Generated from template FilterScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterOperator | Filter operator implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FilterParser | | Class | org.apache.hadoop.hive.metastore.parser | Apache Hive |
|
| FilterPredicateLeafBuilder | The base class for building parquet supported filter predicate in primary types. | Class | org.apache.hadoop.hive.ql.io.parquet | Apache Hive |
|
| FilterScalarAndColumn | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterScalarOrColumn | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterSelectivityEstimator | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| FilterService | | Class | org.apache.hive.service | Apache Hive |
|
| FilterStringColLikeStringScalar | Evaluate LIKE filter on a batch for a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterStringColRegExpStringScalar | Evaluate REGEXP filter on a batch for a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterStringColumnBetween | This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringColumnInList | Evaluate an IN filter on a batch for a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FilterStringColumnNotBetween | This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColEqualCharScalar | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColEqualStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColEqualStringGroupScalarBase | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColEqualStringScalar | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColEqualVarCharScalar | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterCharScalar | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterEqualCharScalar | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterEqualStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterEqualStringGroupScalarBase | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterEqualStringScalar | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterEqualVarCharScalar | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterStringGroupScalarBase | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterStringScalar | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColGreaterVarCharScalar | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessCharScalar | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessEqualCharScalar | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessEqualStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessEqualStringGroupScalarBase | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessEqualStringScalar | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessEqualVarCharScalar | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessStringGroupScalarBase | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessStringScalar | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColLessVarCharScalar | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColNotEqualCharScalar | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColNotEqualStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColNotEqualStringGroupScalarBase | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColNotEqualStringScalar | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupColNotEqualVarCharScalar | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupScalarEqualStringGroupColumnBase | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupScalarGreaterEqualStringGroupColumnBase | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupScalarGreaterStringGroupColumnBase | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupScalarLessEqualStringGroupColumnBase | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupScalarLessStringGroupColumnBase | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringGroupScalarNotEqualStringGroupColumnBase | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringScalarEqualStringGroupColumn | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringScalarGreaterEqualStringGroupColumn | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringScalarGreaterStringGroupColumn | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringScalarLessEqualStringGroupColumn | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringScalarLessStringGroupColumn | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterStringScalarNotEqualStringGroupColumn | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColEqualDoubleScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColEqualLongScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColEqualTimestampScalar | Generated from template FilterTimestampColumnCompareTimestampScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColGreaterDoubleScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColGreaterEqualDoubleScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColGreaterEqualLongScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColGreaterEqualTimestampScalar | Generated from template FilterTimestampColumnCompareTimestampScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColGreaterLongScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColGreaterTimestampScalar | Generated from template FilterTimestampColumnCompareTimestampScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColLessDoubleScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColLessEqualDoubleScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColLessEqualLongScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColLessEqualTimestampScalar | Generated from template FilterTimestampColumnCompareTimestampScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColLessLongScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColLessTimestampScalar | Generated from template FilterTimestampColumnCompareTimestampScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColNotEqualDoubleScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColNotEqualLongScalar | Generated from template FilterTimestampColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampColNotEqualTimestampScalar | Generated from template FilterTimestampColumnCompareTimestampScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampScalarEqualTimestampColumn | Generated from template FilterTimestampScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampScalarGreaterEqualTimestampColumn | Generated from template FilterTimestampScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampScalarGreaterTimestampColumn | Generated from template FilterTimestampScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampScalarLessEqualTimestampColumn | Generated from template FilterTimestampScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampScalarLessTimestampColumn | Generated from template FilterTimestampScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterTimestampScalarNotEqualTimestampColumn | Generated from template FilterTimestampScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterVarCharColumnBetween | This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterVarCharColumnNotBetween | This is a generated class to evaluate a [NOT] BETWEEN comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterVarCharScalarEqualStringGroupColumn | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterVarCharScalarGreaterEqualStringGroupColumn | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterVarCharScalarGreaterStringGroupColumn | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterVarCharScalarLessEqualStringGroupColumn | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterVarCharScalarLessStringGroupColumn | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FilterVarCharScalarNotEqualStringGroupColumn | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FireEventRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| FireEventRequestData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| FireEventResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| FlatFileInputFormat | An InputFormat for Plain files with Deserializer records. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| FlatRowContainer | | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| FloatObjectInspector | A FloatObjectInspector inspects an Object representing a Float. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| FooterBuffer | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ForwardDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ForwardOperator | Forward Operator Just forwards. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ForwardWalker | | Class | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| FosterStorageHandler | This class is used to encapsulate the InputFormat, OutputFormat and SerDe artifacts of tables which don't define a SerDe. | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| FSStatsAggregator | | Class | org.apache.hadoop.hive.ql.stats.fs | Apache Hive |
|
| FSStatsPublisher | | Class | org.apache.hadoop.hive.ql.stats.fs | Apache Hive |
|
| FullMapEqualComparer | | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| FuncAbsDecimalToDecimal | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncAbsDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncAbsLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncACosDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncACosLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncASinDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncASinLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncATanDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncATanLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncBin | Vectorized implementation of Bin(long) function that returns string. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncCeilDecimalToDecimal | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncCeilDoubleToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncCeilLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncCosDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncCosLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncDecimalToDouble | This is a superclass for unary decimal functions and expressions returning doubles that operate directly on the input and set the output. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncDecimalToLong | This is a superclass for unary decimal functions and expressions returning integers that operate directly on the input and set the output. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncDegreesDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncDegreesLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncDoubleToDecimal | This is a superclass for unary double functions and expressions returning decimals that operate directly on the input and set the output. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncExpDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncExpLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncFloorDecimalToDecimal | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncFloorDoubleToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncFloorLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncHex | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncLnDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncLnLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncLog10DoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncLog10LongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncLog2DoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncLog2LongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncLogWithBaseDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncLogWithBaseLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncLongToDecimal | This is a superclass for unary long functions and expressions returning decimals that operate directly on the input and set the output. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncLongToString | Superclass to support vectorized functions that take a long and return a string, optionally with additional configuraiton arguments. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncNegateDecimalToDecimal | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncPowerDoubleToDouble | Vectorized implementation for Pow(a, power) and Power(a, power)See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncPowerLongToDouble | Vectorized implementation for Pow(a, power) and Power(a, power)See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncRadiansDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncRadiansLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncRand | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncRandNoSeed | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncRoundDecimalToDecimal | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncRoundDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncRoundWithNumDigitsDecimalToDecimal | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| FuncSignDecimalToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncSignDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncSignLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncSinDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncSinLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncSqrtDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncSqrtLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncTanDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| FuncTanLongToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| Function | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| FunctionInfo | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FunctionRegistry | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FunctionSemanticAnalyzer | FunctionSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| FunctionTask | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FunctionType | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| FunctionUtils | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| FunctionWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| Generator | This class generates the lineage information for the columns and tables from the plan before it goes through other | Class | org.apache.hadoop.hive.ql.optimizer.lineage | Apache Hive |
|
| GenericMR | This class attempts to provide a simple framework for writing Hive map/reduce The main benefit is that it deals with grouping the keys together for reduce | Class | org.apache.hadoop.hive.contrib.mr | Apache Hive |
|
| GenericUDAFAverage | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFBridge | This class is a bridge between GenericUDAF and UDAF. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFCollectList | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFCollectSet | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFComputeStats | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFContextNGrams | Estimates the top-k contextual n-grams in arbitrary sequential data using a heuristic. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFCorrelation | Compute the Pearson correlation coefficient corr(x, y), using the following stable one-pass method, based on: | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFCount | This class implements the COUNT aggregation function as in SQL. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFCovariance | Compute the covariance covar_pop(x, y), using the following one-pass method (ref. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFCovarianceSample | Compute the sample covariance by extending GenericUDAFCovariance and overriding the terminate() method of the evaluator. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFCumeDist | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFDenseRank | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFEvaluator | A Generic User-defined aggregation function (GenericUDAF) for the use with New GenericUDAF classes need to inherit from this GenericUDAF class. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFEWAHBitmap | GenericUDAFEWAHBitmap. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFFirstValue | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFHistogramNumeric | Computes an approximate histogram of a numerical column using a user-specified number of bins. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFLag | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFLastValue | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFLead | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFLeadLag | abstract class for Lead & lag UDAFs GenericUDAFLeadLag. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFMax | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFMin | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFMkCollectionEvaluator | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFnGrams | Estimates the top-k n-grams in arbitrary sequential data using a heuristic. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFNTile | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFParameterInfo | A callback interface used in conjunction with GenericUDAFResolver2 interface that allows for a more extensible and flexible means of | Interface | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFPercentileApprox | 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. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFPercentRank | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFRank | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFResolver | A Generic User-defined aggregation function (GenericUDAF) for the use with GenericUDAFResolver is used at compile time. | Interface | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFResolver2 | This interface extends the GenericUDAFResolver interface and provides more flexibility in terms of discovering the parameter types | Interface | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFRowNumber | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFStd | Compute the standard deviation by extending GenericUDAFVariance and overriding the terminate() method of the evaluator. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFStdSample | Compute the sample standard deviation by extending GenericUDAFVariance and overriding the terminate() method of the evaluator. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFStreamingEvaluator | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFSum | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFVariance | Compute the variance. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDAFVarianceSample | Compute the sample variance by extending GenericUDAFVariance and overriding the terminate() method of the evaluator. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDF | A Generic User-defined function (GenericUDF) for the use with Hive. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFAbs | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFAddMonths | GenericUDFAddMonths. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFArray | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFArrayContains | GenericUDFArrayContains. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFAssertTrue | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBaseArithmetic | Wrapper UDF that will instantiate the proper arithmetic UDF (numeric, date, etc) depending on the argument types | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBaseBinary | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBaseCompare | GenericUDF Base Class for operations. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBaseDTI | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBaseNumeric | GenericUDF Base Class for operations. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBasePad | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBaseTrim | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBaseUnary | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBetween | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFBridge | GenericUDFBridge encapsulates UDF to provide the same interface as Note that GenericUDFBridge implements Serializable because the name of the | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFCase | GenericUDF Class for SQL construct "CASE a WHEN b THEN c [ELSE f] END". | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFCbrt | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFCeil | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFCoalesce | GenericUDF Class for SQL construct "COALESCE(a, b, c)". | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFConcat | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFConcatWS | Generic UDF for string function CONCAT_WS. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFCurrentDate | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFCurrentTimestamp | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFCurrentUser | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFDate | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFDateAdd | Add a number of days to the date. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFDateDiff | Calculate the difference in the number of days. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFDateFormat | GenericUDFDateFormat. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFDateSub | Subtract a number of days to the date. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFDBOutput | GenericUDFDBOutput is designed to output data directly from Hive to a JDBC datastore. | Class | org.apache.hadoop.hive.contrib.genericudf.example | Apache Hive |
|
| GenericUDFDecode | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFElt | Generic UDF for string function ELT(N,str1,str2,str3,. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFEncode | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFEWAHBitmapAnd | GenericEWAHUDFBitmapAnd. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFEWAHBitmapEmpty | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFEWAHBitmapOr | GenericUDFEWAHBitmapOr. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFFactorial | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFField | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFFloor | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFFloorCeilBase | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFFormatNumber | Generic UDF for format_number function FORMAT_NUMBER(X, D). | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFFromUtcTimestamp | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFGreatest | GenericUDF Class for SQL construct "greatest(v1, v2, . | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFHash | GenericUDF Class for computing hash values. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFIf | IF(expr1,expr2,expr3) If expr1 is TRUE (expr1 NULL) then IF() returns expr2; | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFIn | SELECT key FROM src WHERE key IN ("238", "1"); From MySQL page on IN(): To comply with the SQL standard, IN returns NULL | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFIndex | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFInFile | IN_FILE(str, filename) returns true if 'str' appears in the file specified by 'filename'. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFInitCap | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFInstr | Generic UDF for string function INSTR(str,substr). | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLag | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLastDay | Returns the last day of the month which the date belongs to. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLead | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLeadLag | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLeast | GenericUDF Class for SQL construct "least(v1, v2, . | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLevenshtein | GenericUDFLevenshtein. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLocate | Generic UDF for string function LOCATE(substr, str), LOCATE(substr, str, start). | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLower | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLpad | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFLTrim | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFMacro | GenericUDFMacro wraps a user-defined macro expression into a GenericUDFSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFMap | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFMapKeys | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFMapValues | GenericUDFMapValues. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFMonthsBetween | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFNamedStruct | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFNextDay | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFNvl | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPAnd | GenericUDF Class for computing and. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPDivide | Note that in SQL, the return type of divide is not necessarily the same as the parameters. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPDTIMinus | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPDTIPlus | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPEqual | GenericUDF Class for operation EQUAL. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPEqualNS | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPEqualOrGreaterThan | GenericUDF Class for operation EqualOrGreaterThan. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPEqualOrLessThan | GenericUDF Class for operation EqualOrLessThan. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPGreaterThan | GenericUDF Class for operation GreaterThan. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPLessThan | GenericUDF Class for operation LessThan. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPMinus | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPMod | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPMultiply | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPNegative | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPNot | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPNotEqual | GenericUDF Class for operation Not EQUAL. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPNotNull | GenericUDFOPNotNull. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPNull | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPNumericMinus | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPNumericPlus | 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 | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPOr | GenericUDF Class for computing or. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPPlus | 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 | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFOPPositive | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFPosMod | class for computing positive modulo. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFPower | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFPrintf | Generic UDF for printf function printf(String format, Obj. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFReflect | A simple generic udf to call java static functions via reflection. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFReflect2 | A simple generic udf to call java functions via reflection. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFRound | Note: rounding function permits rounding off integer digits in decimal numbers, which essentially downgrades the scale to negative territory. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFRpad | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFRTrim | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFSentences | GenericUDFSentences: splits a natural language chunk of text into sentences and words. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFSize | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFSortArray | Generic UDF for array sort SORT_ARRAY(array(obj1, obj2, obj3. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFSoundex | Soundex is an encoding used to relate similar names, but can also be used as a general purpose scheme to find word with similar phonemes. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFSplit | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFStringToMap | GenericUDFStringToMap. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFStruct | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFTimestamp | . | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToBinary | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToChar | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToDate | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToDecimal | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToIntervalDayTime | GenericUDFIntervalDayTime . | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToIntervalYearMonth | GenericUDFIntervalYearMonth . | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToUnixTimeStamp | deterministic version of UDFUnixTimeStamp. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToUtcTimestamp | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFToVarchar | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFTranslate | TRANSLATE(string input, string from, string to) is an equivalent function to translate in PostGresSQL. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFTrim | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFTrunc | Returns the first day of the month which the date belongs to. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFUnion | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFUnixTimeStamp | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFUpper | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFUtils | Util functions for GenericUDF classes. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFWhen | GenericUDF Class for SQL construct "CASE WHEN a THEN b WHEN c THEN d [ELSE f] END". | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDFXPath | | Class | org.apache.hadoop.hive.ql.udf.xml | Apache Hive |
|
| GenericUDTF | A Generic User-defined Table Generating Function (UDTF) Generates a variable number of output rows for a single input row. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDTFCount2 | GenericUDTFCount2 outputs the number of rows seen, twice. | Class | org.apache.hadoop.hive.contrib.udtf.example | Apache Hive |
|
| GenericUDTFExplode | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDTFExplode2 | GenericUDTFExplode2. | Class | org.apache.hadoop.hive.contrib.udtf.example | Apache Hive |
|
| GenericUDTFInline | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDTFJSONTuple | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDTFParseUrlTuple | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDTFPosExplode | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenericUDTFStack | Takes a row of size k of data and splits it into n rows of data. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| GenHiveTemplate | Generates hive-default. | Class | org.apache.hadoop.hive.ant | Apache Hive |
|
| GenMapRedUtils | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenMapRedWalker | Walks the operator tree in pre order fashion. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| GenMRFileSink1 | Processor for the rule - table scan followed by reduce sink. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenMROperator | Processor for the rule - no specific rule fired. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenMRProcContext | Processor Context for creating map reduce task. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenMRRedSink1 | Processor for the rule - table scan followed by reduce sink. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenMRRedSink2 | Processor for the rule - reduce sink followed by reduce sink. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenMRRedSink3 | Processor for the rule - union followed by reduce sink. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenMRSkewJoinProcessor | GenMRSkewJoinProcessor. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| GenMRTableScan1 | Processor for the rule - table scan. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenMRUnion1 | Processor for the rule - TableScan followed by Union. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GenSparkProcContext | GenSparkProcContext maintains information about the tasks and operators as we walk the operator tree to break them into SparkTasks. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| GenSparkSkewJoinProcessor | Copied from GenMRSkewJoinProcessor. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| GenSparkUtils | GenSparkUtils is a collection of shared helper methods to produce SparkWork Cloned from GenTezUtils. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| GenSparkWork | GenSparkWork separates the operator tree into spark tasks. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| GenSparkWorkWalker | Walks the operator tree in DFS fashion. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| GenTezProcContext | GenTezProcContext. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| GenTezUtils | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| GenTezWork | GenTezWork separates the operator tree into tez tasks. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| GenTezWorkWalker | Walks the operator tree in DFS fashion. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| GenVectorCode | This class generates java classes from the templates. | Class | org.apache.hadoop.hive.ant | Apache Hive |
|
| GenVectorTestCode | This class is mutable and maintains a hashmap of TestSuiteClassName to test cases. | Class | org.apache.hadoop.hive.ant | Apache Hive |
|
| GetCatalogsOperation | GetCatalogsOperation. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| GetColumnsOperation | GetColumnsOperation. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| GetFunctionsOperation | GetFunctionsOperation. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| GetInfoType | | Class | org.apache.hive.service.cli | Apache Hive |
|
| GetInfoValue | | Class | org.apache.hive.service.cli | Apache Hive |
|
| GetOpenTxnsInfoResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GetOpenTxnsResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GetPrincipalsInRoleRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GetPrincipalsInRoleResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GetRoleGrantsForPrincipalRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GetRoleGrantsForPrincipalResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GetSchemasOperation | GetSchemasOperation. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| GetTablesOperation | | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| GetTableTypesOperation | GetTableTypesOperation. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| GetTypeInfoOperation | GetTypeInfoOperation. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| GetVersionPref | This ant task takes an input version string (e. | Class | org.apache.hadoop.hive.ant | Apache Hive |
|
| GlobalLimitCtx | context for pruning inputs. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| GlobalLimitOptimizer | This optimizer is used to reduce the input size for the query for queries which are specifying a limit. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GrantDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| GrantPrivAuthUtils | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| GrantRevokePrivilegeRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GrantRevokePrivilegeResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GrantRevokeRoleDDL | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| GrantRevokeRoleRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GrantRevokeRoleResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| GrantRevokeType | enum GrantRevokeTypeEnum Constant Summary | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| Graph | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| GraphWalker | Interface for operator graph walker. | Interface | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| GreaterThan | Wraps call to greaterThan over PrimitiveComparison instance. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| GreaterThanOrEqual | Wraps call to greaterThanOrEqual over PrimitiveComparison instance. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| GroupByDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| GroupByOperator | GroupBy operator implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| GroupByOptimizer | This transformation does group by optimization. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| GroupByShuffler | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| GroupPermissionsDesc | The base create permissions for ddl objects. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| Hadoop20SShims | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| Hadoop23Shims | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| HadoopDefaultAuthenticator | | Class | org.apache.hadoop.hive.ql.security | Apache Hive |
|
| HadoopDefaultMetastoreAuthenticator | | Class | org.apache.hadoop.hive.ql.security | Apache Hive |
|
| HadoopJobExecHelper | | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| HadoopJobExecHook | | Interface | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| HadoopShims | In order to be compatible with multiple versions of Hadoop, all parts of the Hadoop interface that are not cross-version compatible are | Interface | org.apache.hadoop.hive.shims | Apache Hive |
|
| HadoopShimsSecure | Base implemention for shims against secure Hadoop 0. | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| HadoopThriftAuthBridge | Functions that bridge Thrift's SASL transports to Hadoop's SASL callback handlers and authentication classes. | Class | org.apache.hadoop.hive.thrift | Apache Hive |
|
| HadoopThriftAuthBridge23 | Functions that bridge Thrift's SASL transports to Hadoop's SASL callback handlers and authentication classes. | Class | org.apache.hadoop.hive.thrift | Apache Hive |
|
| Handle | | Class | org.apache.hive.service.cli | Apache Hive |
|
| HandleIdentifier | | Class | org.apache.hive.service.cli | Apache Hive |
|
| HarOutputCommitterPostProcessor | | Class | org.apache.hive.hcatalog.har | Apache Hive |
|
| HashMapWrapper | Simple wrapper for persistent Hashmap implementing only the put/get/remove/clear interface. | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| HashTableDummyDesc | HashTable Dummy Descriptor implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| HashTableDummyOperator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| HashTableLoader | HashTableLoader is an interface used by MapJoinOperator used to load the hashtables needed to process the join. | Interface | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| HashTableLoader | HashTableLoader for MR loads the hashtable for MapJoins from local disk (hashtables are distributed by using the DistributedCache. | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| HashTableLoader | HashTableLoader for Spark to load the hashtable for MapJoins. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HashTableLoader | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| HashTableLoaderFactory | HashTableLoaderFactory is used to determine the strategy of loading the hashtables for the MapJoinOperator | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| HashTableSinkDesc | Map Join operator Descriptor implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| HashTableSinkOperator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| HBaseCompositeKey | HBaseCompositeKey extension of LazyStruct. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseKeyFactory | Provides custom implementation of object and object inspector for hbase key. | Interface | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseLazyObjectFactory | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseRowSerializer | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseScanRange | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseSerDe | HBaseSerDe can be used to serialize object into an HBase table and deserialize objects from an HBase table. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseSerDeHelper | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseSerDeParameters | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseSplit | HBaseSplit augments FileSplit with HBase column mapping. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseStatsAggregator | A class that implements the StatsAggregator interface through HBase. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseStatsPublisher | A class that implements the StatsPublisher interface through HBase. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseStatsSetupConstants | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseStatsUtils | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseStorageHandler | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseStructValue | This is an extension of LazyStruct. | Class | org.apache.hadoop.hive.hbase.struct | Apache Hive |
|
| HBaseTableSnapshotInputFormatUtil | A helper class to isolate newer HBase features from users running against older versions of HBase that don't provide those features. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HBaseValueFactory | Provides capability to plugin custom implementations for querying of data stored in HBase. | Interface | org.apache.hadoop.hive.hbase.struct | Apache Hive |
|
| HCatAddPartitionDesc | The Class HCatAddPartitionDesc helps users in defining partition attributes. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatBaseInputFormat | | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| HCatBaseOutputFormat | | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| HCatCli | | Class | org.apache.hive.hcatalog.cli | Apache Hive |
|
| HCatClient | The abstract class HCatClient containing APIs for HCatalog DDL commands. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatClientHMSImpl | | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatConstants | | Class | org.apache.hive.hcatalog.common | Apache Hive |
|
| HCatContext | HCatContext is a singleton that provides global access to configuration data. | Class | org.apache.hive.hcatalog.common | Apache Hive |
|
| HCatCreateDBDesc | The Class HCatCreateDBDesc for defining database attributes. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatCreateTableDesc | The Class HCatCreateTableDesc for defining attributes for a new table. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatDatabase | HCatDatabase is wrapper class around org. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HcatDelegator | Run hcat on the local server using the ExecService. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| HCatDriver | | Class | org.apache.hive.hcatalog.cli | Apache Hive |
|
| HCatEventMessage | Class representing messages emitted when Metastore operations are done. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| HCatException | Class representing exceptions thrown by HCat. | Class | org.apache.hive.hcatalog.common | Apache Hive |
|
| HcatException | Unable to run hcat on the job. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| HCatFieldSchema | | Class | org.apache.hive.hcatalog.data.schema | Apache Hive |
|
| HCatFileUtil | | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| HCatInputFormat | The InputFormat to use to read data from HCatalog. | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| HCatInputFormatReader | | Class | org.apache.hive.hcatalog.data.transfer.impl | Apache Hive |
|
| HCatLoader | | Class | org.apache.hive.hcatalog.pig | Apache Hive |
|
| HCatMapRedUtil | | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| HCatNotificationEvent | A wrapper class for NotificationEvent, so that if that class changes we can still keep this one constant for backward compatibility | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatOutputFormat | The OutputFormat to use to write data to HCatalog. | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| HCatOutputFormatWriter | | Class | org.apache.hive.hcatalog.data.transfer.impl | Apache Hive |
|
| HCatPartition | The HCatPartition is a wrapper around org. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatPartitionSpec | Generalized representation of a set of HCatPartitions. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatReader | This abstract class is internal to HCatalog and abstracts away the notion of underlying system from which reads will be done. | Class | org.apache.hive.hcatalog.data.transfer | Apache Hive |
|
| HCatRecord | Abstract class exposing get and set semantics for basic record usage. | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| HCatRecordable | | Interface | org.apache.hive.hcatalog.data | Apache Hive |
|
| HCatRecordObjectInspector | | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| HCatRecordObjectInspectorFactory | | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| HCatRecordSerDe | | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| HCatReplicationTaskIterator | | Class | org.apache.hive.hcatalog.api.repl | Apache Hive |
|
| HCatSchema | HCatSchema. | Class | org.apache.hive.hcatalog.data.schema | Apache Hive |
|
| HCatSchemaUtils | | Class | org.apache.hive.hcatalog.data.schema | Apache Hive |
|
| HCatSemanticAnalyzer | | Class | org.apache.hive.hcatalog.cli.SemanticAnalysis | Apache Hive |
|
| HCatSemanticAnalyzerBase | Base class for HCatSemanticAnalyzer hooks. | Class | org.apache.hive.hcatalog.cli.SemanticAnalysis | Apache Hive |
|
| HCatSplit | | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| HCatStorer | | Class | org.apache.hive.hcatalog.pig | Apache Hive |
|
| HCatTable | The HCatTable is a wrapper around org. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| HCatTableInfo | HCatTableInfo - class to communicate table information to HCatInputFormat and HCatOutputFormat | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| HCatUtil | | Class | org.apache.hive.hcatalog.common | Apache Hive |
|
| HCatWriter | This abstraction is internal to HCatalog. | Class | org.apache.hive.hcatalog.data.transfer | Apache Hive |
|
| HDFSCleanup | | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| HDFSStorage | HDFS implementation of templeton storage. | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| Heartbeater | Class to handle heartbeats for MR and Tez tasks. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| HeartBeatFailure | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| HeartbeatRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| HeartbeatTxnRangeRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| HeartbeatTxnRangeResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| Hive | This class has functions that implement meta data/DDL operations using calls It has a metastore client instance it uses to communicate with the metastore. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| hive_metastoreConstants | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| HiveAccessControlException | Exception thrown by the Authorization plugin api (v2). | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveAccessController | Interface that is invoked by access control commands, including grant/revoke role/privileges, create/drop roles, and commands to read the state of authorization rules. | Interface | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveAccumuloColumnMapping | | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| HiveAccumuloHelper | Helper class to hold common methods across the InputFormat, OutputFormat and StorageHandler. | Class | org.apache.hadoop.hive.accumulo | Apache Hive |
|
| HiveAccumuloMapColumnMapping | ColumnMapping for combining Accumulo columns into a single Hive Map. | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| HiveAccumuloRecordReader | Translate the Key Value pairs from AccumuloInputFormat to a Writable for consumption by the AccumuloSerDe. | Class | org.apache.hadoop.hive.accumulo.mr | Apache Hive |
|
| HiveAccumuloRowIdColumnMapping | | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| HiveAccumuloSplit | Wraps RangeInputSplit into a FileSplit so Hadoop won't complain when it tries to make its own If the RangeInputSplit is used directly, it will hit a branch of code in | Class | org.apache.hadoop.hive.accumulo.mr | Apache Hive |
|
| HiveAccumuloTableInputFormat | Wraps older InputFormat for use with Hive. | Class | org.apache.hadoop.hive.accumulo.mr | Apache Hive |
|
| HiveAccumuloTableOutputFormat | | Class | org.apache.hadoop.hive.accumulo.mr | Apache Hive |
|
| HiveAggregate | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveAlgorithmsConf | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.cost | Apache Hive |
|
| HiveAlgorithmsUtil | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.cost | Apache Hive |
|
| HiveAlterHandler | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| HiveAuthenticationProvider | HiveAuthenticationProvider is an interface for authentication. | Interface | org.apache.hadoop.hive.ql.security | Apache Hive |
|
| HiveAuthFactory | This class helps in some aspects of authentication. | Class | org.apache.hive.service.auth | Apache Hive |
|
| HiveAuthorizationProvider | | Interface | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| HiveAuthorizationProviderBase | | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| HiveAuthorizationTaskFactory | HiveAuthorizationTaskFactory creates DDL authorization related tasks. | Interface | org.apache.hadoop.hive.ql.parse.authorization | Apache Hive |
|
| HiveAuthorizationTaskFactoryImpl | | Class | org.apache.hadoop.hive.ql.parse.authorization | Apache Hive |
|
| HiveAuthorizationValidator | Interface used to check if user has privileges to perform certain action. | Interface | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveAuthorizer | Interface for hive authorization plugins. | Interface | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveAuthorizerFactory | create HiveAuthorizer instance used for hive authorization. | Interface | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveAuthorizerImpl | Convenience implementation of HiveAuthorizer. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveAuthzContext | Provides context information in authorization check call that can be used for auditing and/or authorization. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveAuthzPluginException | Exception thrown by the Authorization plugin api (v2). | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveAuthzSessionContext | Provides session context information. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveBaseChar | | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| HiveBaseCharWritable | | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| HiveBaseFunctionResultList | - collecting Map/Reduce function output and - providing an Iterable interface for fetching output records. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveBaseResultSet | Data independent base class which implements the common part of all Hive result sets. | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveBinaryOutputFormat | HiveBinaryOutputFormat writes out the values consecutively without any separators. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveBurnInClient | | Class | org.apache.hive.testutils.jdbc | Apache Hive |
|
| HiveCalciteUtil | Generic utility functions needed for Calcite based Hive CBO. | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| HiveCallableStatement | HiveCallableStatement. | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveChar | String values will be padded to full char length. | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| HiveCharObjectInspector | | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| HiveCharWritable | String values will be padded to full char length. | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| HiveClusterStatus | | Class | org.apache.hadoop.hive.service | Apache Hive |
|
| HiveCollectionConverter | | Class | org.apache.hadoop.hive.ql.io.parquet.convert | Apache Hive |
|
| HiveColumn | | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| HiveCommand | | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| HiveCommandOperation | | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| HiveCompactIndexInputFormat | | Class | org.apache.hadoop.hive.ql.index.compact | Apache Hive |
|
| HiveCompat | | Class | org.apache.hive.common | Apache Hive |
|
| HiveConf | | Class | org.apache.hadoop.hive.conf | Apache Hive |
|
| HiveConfigContext | | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| HiveConfUtil | | Class | org.apache.hadoop.hive.conf | Apache Hive |
|
| HiveConnection | | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveContextAwareRecordReader | This class prepares an IOContext, and provides the ability to perform a binary search on the data. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveCost | 1. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.cost | Apache Hive |
|
| HiveCostModel | Cost model interface. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.cost | Apache Hive |
|
| HiveDatabaseMetaData | HiveDatabaseMetaData. | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveDataSource | | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveDecimal | HiveDecimal. | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| HiveDecimalObjectInspector | A DecimalObjectInspector inspects an Object representing a HiveDecimal. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| HiveDecimalUtils | | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| HiveDecimalWritable | | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| HiveDefaultCostModel | Default implementation of the cost model. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.cost | Apache Hive |
|
| HiveDefaultRelMetadataProvider | | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| HiveDelegationTokenSupport | Workaround for serialization of AbstractDelegationTokenSecretManager. | Class | org.apache.hadoop.security.token.delegation | Apache Hive |
|
| HiveDelegator | This is the backend of the hive web service. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| HiveDriver | | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveDriverRunHook | HiveDriverRunHook allows Hive to be extended with custom logic for processing commands. | Interface | org.apache.hadoop.hive.ql | Apache Hive |
|
| HiveDriverRunHookContext | | Interface | org.apache.hadoop.hive.ql | Apache Hive |
|
| HiveDriverRunHookContextImpl | | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| HiveEndPoint | Information about the hive end point (i. | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| HiveEventCounter | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| HiveException | Generic exception class for Hive. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| HiveExpandDistinctAggregatesRule | Planner rule that expands distinct aggregates (such as COUNT(DISTINCT x)) from a | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveFatalException | | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| HiveFileFormatUtils | An util class for various Hive file format tasks. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveFileProcessor | | Class | org.apache.hadoop.hive.common.cli | Apache Hive |
|
| HiveFilter | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveFilterJoinRule | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveFilterProjectTransposeRule | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveFilterSetOpTransposeRule | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveGBOpConvUtil | 1. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| HiveGroupConverter | | Class | org.apache.hadoop.hive.ql.io.parquet.convert | Apache Hive |
|
| HiveGroupingID | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveHarFileSystem | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| HiveHBaseTableInputFormat | HiveHBaseTableInputFormat implements InputFormat for HBase storage handler tables, decorating an underlying HBase TableInputFormat with extra Hive logic | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HiveHBaseTableOutputFormat | HiveHBaseTableOutputFormat implements HiveOutputFormat for HBase tables. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HiveHBaseTableSnapshotInputFormat | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HiveHFileOutputFormat | HiveHFileOutputFormat implements HiveOutputFormat for HFile bulk loading. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| HiveHistory | HiveHistory. | Interface | org.apache.hadoop.hive.ql.history | Apache Hive |
|
| HiveHistoryImpl | HiveHistory. | Class | org.apache.hadoop.hive.ql.history | Apache Hive |
|
| HiveHistoryProxyHandler | | Class | org.apache.hadoop.hive.ql.history | Apache Hive |
|
| HiveHistoryUtil | | Class | org.apache.hadoop.hive.ql.history | Apache Hive |
|
| HiveHistoryViewer | | Class | org.apache.hadoop.hive.ql.history | Apache Hive |
|
| HiveIgnoreKeyTextOutputFormat | HiveIgnoreKeyTextOutputFormat replaces key with null before feeding the to TextOutputFormat. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveIndex | | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| HiveIndexedInputFormat | Input format for doing queries that use indexes. | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| HiveIndexHandler | | Interface | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| HiveIndexQueryContext | Used to pass information between the IndexProcessor and the plugin IndexHandler during query processing | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| HiveIndexResult | HiveIndexResult parses the input stream from an index query to generate a list of file splits to query. | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| HiveInputFormat | HiveInputFormat is a parameterized InputFormat which looks at the path name and determine the correct InputFormat for that path name from | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveInsertExchange4JoinRule | Not an optimization rule. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveInterruptCallback | | Interface | org.apache.hadoop.hive.common | Apache Hive |
|
| HiveInterruptUtils | | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| HiveIntervalDayTime | Day-time interval type representing an offset in days/hours/minutes/seconds, with nanosecond precision. | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| HiveIntervalDayTimeObjectInspector | A HiveIntervalObjectInspector inspects an Object representing an Interval. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| HiveIntervalDayTimeWritable | | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| HiveIntervalYearMonth | | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| HiveIntervalYearMonthObjectInspector | A HiveIntervalObjectInspector inspects an Object representing a year-month Interval. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| HiveIntervalYearMonthWritable | | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| HiveIOExceptionHandler | HiveIOExceptionHandler defines an interface that all io exception handler in Hive should implement. | Interface | org.apache.hadoop.hive.io | Apache Hive |
|
| HiveIOExceptionHandlerChain | An exception handler chain that process the input exception by going through all exceptions defined in this chain one by one until either one exception | Class | org.apache.hadoop.hive.io | Apache Hive |
|
| HiveIOExceptionHandlerUtil | | Class | org.apache.hadoop.hive.io | Apache Hive |
|
| HiveIOExceptionNextHandleResult | A container to store handling results for exceptions produced in record reader's next(). | Class | org.apache.hadoop.hive.io | Apache Hive |
|
| HiveJoin | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveJoinAddNotNullRule | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveJoinToMultiJoinRule | Rule that merges a join with multijoin/join children if the equi compared the same set of input columns. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveKey | HiveKey is a simple wrapper on Text which allows us to set the hashCode easily. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveLexer | Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| HiveLimit | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveLock | | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| HiveLockManager | Manager for locks in Hive. | Interface | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| HiveLockManagerCtx | | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| HiveLockMode | | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| HiveLockObj | | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| HiveLockObject | | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| HiveMapFunction | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveMapFunctionResultList | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveMetaDataResultSet | | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveMetaException | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| HiveMetaHook | HiveMetaHook defines notification methods which are invoked as part of transactions against the metastore, allowing external catalogs | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| HiveMetaHookLoader | | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| HiveMetaStore | TODO:pc remove application logic to a separate interface. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| HiveMetastoreAuthenticationProvider | HiveMetastoreAuthenticationProvider is an interface extension from HiveAuthenticationProvider for authentication from the | Interface | org.apache.hadoop.hive.ql.security | Apache Hive |
|
| HiveMetastoreAuthorizationProvider | HiveMetastoreAuthorizationProvider : An extension of HiveAuthorizaytionProvider that is intended to be called from the metastore-side. | Interface | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| HiveMetaStoreChecker | Verify that the information in the metastore matches what is on the filesystem. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| HiveMetaStoreClient | Hive Metastore Client. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| HiveMetastoreClientFactory | Factory for getting current valid instance of IMetaStoreClient Metastore client cannot be cached in authorization interface as that | Interface | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveMetastoreClientFactoryImpl | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveMetaStoreFsImpl | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| HiveMetaTool | This class provides Hive admins a tool to - execute JDOQL against the metastore using DataNucleus | Class | org.apache.hadoop.hive.metastore.tools | Apache Hive |
|
| HiveMultiPartitionAuthorizationProviderBase | Abstract class that allows authorization of operations on partition-sets. | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| HiveNullValueSequenceFileOutputFormat | A HiveOutputFormat that writes SequenceFiles with the content saved in the keys, and null in the values. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveObjectPrivilege | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| HiveObjectRef | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| HiveObjectType | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| HiveOnTezCostModel | Cost model for Tez execution engine. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.cost | Apache Hive |
|
| HiveOpConverter | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| HiveOpConverterPostProc | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| HiveOperation | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| HiveOperationType | enum HiveOperationTypeList of hive operations types. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveOutputFormat | HiveOutputFormat describes the output-specification for Hive's operators. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveOutputFormatImpl | Hive does not use OutputFormat's in a conventional way, but constructs and uses the defined OutputFormat for each table from FileSinkOperator. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HivePairFlatMapFunction | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveParser | Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| HiveParser_FromClauseParser | Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| HiveParser_IdentifiersParser | Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| HiveParser_SelectClauseParser | Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| HivePartitioner | Partition keys by their Object. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HivePartitionPruneRule | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HivePassThroughOutputFormat | This pass through class is used to wrap OutputFormat implementations such that new OutputFormats not derived from HiveOutputFormat gets through the checker | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HivePassThroughRecordWriter | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HivePreFilteringRule | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HivePreparedStatement | HivePreparedStatement. | Class | org.apache.hive.jdbc | Apache Hive |
|
| HivePreWarmProcessor | A simple sleep processor implementation that sleeps for the configured time in milliseconds. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| HivePrincipal | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HivePrivilege | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HivePrivilegeInfo | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HivePrivilegeObject | Represents the object on which privilege is being granted/revoked, and objects being used in queries. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HivePrivilegeObjectUtils | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveProject | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveProjectMergeRule | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveQueryResultSet | | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveRecordReader | HiveRecordReader is a simple wrapper on RecordReader. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveReduceFunction | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveReduceFunctionResultList | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveRelCollation | | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| HiveRelDistribution | | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| HiveRelFieldTrimmer | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HiveRelMdCollation | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelMdCost | HiveRelMdCost supplies the implementation of cost model. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.cost | Apache Hive |
|
| HiveRelMdDistinctRowCount | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelMdDistribution | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelMdMemory | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelMdParallelism | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelMdRowCount | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelMdSelectivity | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelMdSize | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelMdUniqueKeys | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.stats | Apache Hive |
|
| HiveRelNode | | Interface | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveRelOptUtil | | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| HiveResultSetMetaData | HiveResultSetMetaData. | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveRoleGrant | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveSchemaConverter | | Class | org.apache.hadoop.hive.ql.io.parquet.convert | Apache Hive |
|
| HiveSchemaHelper | | Class | org.apache.hive.beeline | Apache Hive |
|
| HiveSchemaTool | | Class | org.apache.hive.beeline | Apache Hive |
|
| HiveSemanticAnalyzerHook | HiveSemanticAnalyzerHook allows Hive to be extended with custom logic for semantic analysis of QL statements. | Interface | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| HiveSemanticAnalyzerHookContext | Context information provided by Hive to implementations of HiveSemanticAnalyzerHook. | Interface | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| HiveSemanticAnalyzerHookContextImpl | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| HiveSequenceFileOutputFormat | A HiveOutputFormat that writes SequenceFiles. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| HiveServer2 | | Class | org.apache.hive.service.server | Apache Hive |
|
| HiveServerException | | Class | org.apache.hadoop.hive.service | Apache Hive |
|
| HiveSession | | Interface | org.apache.hive.service.cli.session | Apache Hive |
|
| HiveSessionBase | Methods that don't need to be executed under a doAs context are here. | Interface | org.apache.hive.service.cli.session | Apache Hive |
|
| HiveSessionHook | HiveServer2 session level Hook interface. | Interface | org.apache.hive.service.cli.session | Apache Hive |
|
| HiveSessionHookContext | HiveSessionHookContext. | Interface | org.apache.hive.service.cli.session | Apache Hive |
|
| HiveSessionHookContextImpl | HiveSessionHookContextImpl. | Class | org.apache.hive.service.cli.session | Apache Hive |
|
| HiveSessionImpl | | Class | org.apache.hive.service.cli.session | Apache Hive |
|
| HiveSessionImplwithUGI | HiveSessionImplwithUGI. | Class | org.apache.hive.service.cli.session | Apache Hive |
|
| HiveSessionProxy | | Class | org.apache.hive.service.cli.session | Apache Hive |
|
| HiveSort | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveSortExchange | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveSparkClient | | Interface | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveSparkClientFactory | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveSplitGenerator | This class is used to generate splits inside the AM on the cluster. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| HiveSQLException | | Class | org.apache.hive.service.cli | Apache Hive |
|
| HiveStatement | | Class | org.apache.hive.jdbc | Apache Hive |
|
| HiveStatsUtils | A collection of utilities used for hive statistics. | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| HiveStorageHandler | HiveStorageHandler defines a pluggable interface for adding new storage handlers to Hive. | Interface | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| HiveStoragePredicateHandler | 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. | Interface | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| HiveStringUtils | General string utils Originally copied from o. | Class | org.apache.hive.common.util | Apache Hive |
|
| HiveStructConverter | A MapWritableGroupConverter, real converter between hive and parquet types recursively for complex types. | Class | org.apache.hadoop.hive.ql.io.parquet.convert | Apache Hive |
|
| HiveTableScan | Relational expression representing a scan of a HiveDB collection. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveTableTypeMapping | HiveTableTypeMapping. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| HiveTestUtils | | Class | org.apache.hive.common.util | Apache Hive |
|
| HiveTotalOrderPartitioner | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| HiveTxnManager | An interface that allows Hive to manage transactions. | Interface | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| HiveTypeSystemImpl | | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| HiveUnion | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.reloperators | Apache Hive |
|
| HiveUtils | General collection of helper functions. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| HiveV1Authorizer | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| HiveVarchar | String wrapper to support SQL VARCHAR features. | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| HiveVarcharObjectInspector | | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| HiveVarcharWritable | | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| HiveVersionAnnotation | HiveVersionAnnotation. | Class | org.apache.hive.common | Apache Hive |
|
| HiveVersionInfo | | Class | org.apache.hive.common.util | Apache Hive |
|
| HiveVoidFunction | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| HiveVolcanoPlanner | Refinement of VolcanoPlanner for Hive. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.cost | Apache Hive |
|
| HiveWindowingFixRule | Rule to fix windowing issue when it is done over aggregation columns (more info in HIVE-10627). | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| HookContext | Hook Context keeps all the necessary information for all the hooks. | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| HookUtils | | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| HttpAuthenticationException | | Class | org.apache.hive.service.auth | Apache Hive |
|
| HttpAuthUtils | Utility functions for HTTP mode authentication. | Class | org.apache.hive.service.auth | Apache Hive |
|
| HttpBasicAuthInterceptor | The class is instantiated with the username and password, it is then used to add header with these credentials to HTTP requests | Class | org.apache.hive.jdbc | Apache Hive |
|
| HttpKerberosRequestInterceptor | Authentication interceptor which adds Base64 encoded payload, containing the username and kerberos service ticket, | Class | org.apache.hive.jdbc | Apache Hive |
|
| HttpRequestInterceptorBase | | Class | org.apache.hive.jdbc | Apache Hive |
|
| HWIAuth | Represents an authenticated user. | Class | org.apache.hadoop.hive.hwi | Apache Hive |
|
| HWIContextListener | After getting a contextInitialized event this component starts an instance of the HiveSessionManager. | Class | org.apache.hadoop.hive.hwi | Apache Hive |
|
| HWIException | | Class | org.apache.hadoop.hive.hwi | Apache Hive |
|
| HWIServer | This is the entry point for HWI. | Class | org.apache.hadoop.hive.hwi | Apache Hive |
|
| HWISessionItem | HWISessionItem can be viewed as a wrapper for a Hive shell. | Class | org.apache.hadoop.hive.hwi | Apache Hive |
|
| HWISessionManager | HiveSessionManager is a Runnable started inside a web application context. | Class | org.apache.hadoop.hive.hwi | Apache Hive |
|
| HybridHashTableConf | This conf class is a wrapper of a list of HybridHashTableContainers and some common info shared among them, which is used in n-way join (multiple small tables are involved). | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| HybridHashTableContainer | Hash table container that can have many partitions -- each partition has its own hashmap, as well as row container for small table and big table. | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| ICLIService | | Interface | org.apache.hive.service.cli | Apache Hive |
|
| IdentityExpression | An expression representing a column, only children are evaluated. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IdentityMapper | Example Mapper (Identity). | Class | org.apache.hadoop.hive.contrib.mr.example | Apache Hive |
|
| IdentityProjectRemover | This optimization tries to remove SelectOperator from tree which don't do any processing except forwarding columns from its parent to its children. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| IDoubleInExpr | Interface used for both filter and non-filter versions of IN to simplify VectorizationContext code. | Interface | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IExtrapolatePartStatus | | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| IfExprCharScalarStringGroupColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprCharScalarStringScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprDoubleColumnDoubleColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprDoubleColumnDoubleScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprDoubleColumnLongScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprDoubleScalarDoubleColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprDoubleScalarDoubleScalar | Compute IF(expr1, expr2, expr3) for 3 input expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprDoubleScalarLongColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprDoubleScalarLongScalar | Compute IF(expr1, expr2, expr3) for 3 input expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprLongColumnDoubleScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprLongColumnLongColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprLongColumnLongScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprLongScalarDoubleColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprLongScalarDoubleScalar | Compute IF(expr1, expr2, expr3) for 3 input expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprLongScalarLongColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprLongScalarLongScalar | Compute IF(expr1, expr2, expr3) for 3 input expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IfExprStringGroupColumnCharScalar | Compute IF(expr1, expr2, expr3) for 3 input expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprStringGroupColumnStringGroupColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprStringGroupColumnStringScalar | Compute IF(expr1, expr2, expr3) for 3 input expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprStringGroupColumnVarCharScalar | Compute IF(expr1, expr2, expr3) for 3 input expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprStringScalarCharScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprStringScalarStringGroupColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprStringScalarStringScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprStringScalarVarCharScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprVarCharScalarStringGroupColumn | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IfExprVarCharScalarStringScalar | Compute IF(expr1, expr2, expr3) for 3 input column expressions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IgnoreKeyTextOutputFormat | This class replaces key with null before feeding the to TextOutputFormat. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| IHiveFileProcessor | | Interface | org.apache.hadoop.hive.common.cli | Apache Hive |
|
| IHMSHandler | | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| ILongInExpr | Interface used for both filter and non-filter versions of IN to simplify VectorizationContext code. | Interface | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IMetaStoreClient | | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| ImpersonationFailed | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| ImportCommand | | Class | org.apache.hive.hcatalog.api.repl.commands | Apache Hive |
|
| ImportSemanticAnalyzer | ImportSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| IncrementalRows | Rows implementation which returns rows incrementally from result set without any buffering. | Class | org.apache.hive.beeline | Apache Hive |
|
| Index | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| IndexAlreadyExistsException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| IndexMetadataChangeTask | | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| IndexMetadataChangeWork | | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| IndexPredicateAnalyzer | IndexPredicateAnalyzer decomposes predicates, separating the parts which can be satisfied by an index from the parts which cannot. | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| IndexSearchCondition | IndexSearchCondition represents an individual search condition found by IndexPredicateAnalyzer. | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| IndexUpdater | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| IndexUtils | Utility class for index support. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| IndexWhereProcCtx | | Class | org.apache.hadoop.hive.ql.optimizer.physical.index | Apache Hive |
|
| IndexWhereProcessor | IndexWhereProcessor. | Class | org.apache.hadoop.hive.ql.optimizer.physical.index | Apache Hive |
|
| IndexWhereResolver | | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| IndexWhereTaskDispatcher | IndexWhereTaskDispatcher. | Class | org.apache.hadoop.hive.ql.optimizer.physical.index | Apache Hive |
|
| Initiator | A class to initiate compactions. | Class | org.apache.hadoop.hive.ql.txn.compactor | Apache Hive |
|
| InnerStruct | | Class | org.apache.hadoop.hive.serde.test | Apache Hive |
|
| InputByteBuffer | This class is much more efficient than ByteArrayInputStream because none of the methods are synchronized. | Class | org.apache.hadoop.hive.serde2.binarysortable | Apache Hive |
|
| InputEstimator | | Interface | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| InputFormatChecker | Check for validity of the input files. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| InputJobInfo | Container for metadata read from the metadata server. | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| InputMetrics | Metrics pertaining to reading input data. | Class | org.apache.hive.spark.client.metrics | Apache Hive |
|
| InputSignature | The input signature of a function or operator. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| InsertEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| InsertEventRequestData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| InsertMessage | HCat message sent when an insert is done to a table or partition. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| InsertReplicationTask | | Class | org.apache.hive.hcatalog.api.repl.exim | Apache Hive |
|
| InspectableObject | Simple wrapper of object with ObjectInspector. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| InstanceCache | Cache for objects whose creation only depends on some other set of objects and therefore can be used against other equivalent versions of those | Class | org.apache.hadoop.hive.serde2.avro | Apache Hive |
|
| InStream | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| IntCompare | Set of comparison operations over a integer constant. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| IntegerColumnStatistics | | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| InterfaceAudience | Annotation to inform users of a package, class or method's intended audience. | Class | org.apache.hadoop.hive.common.classification | Apache Hive |
|
| InterfaceStability | Annotation to inform users of how much to rely on a particular package, class or method not changing over time. | Class | org.apache.hadoop.hive.common.classification | Apache Hive |
|
| IntervalDayTimeColAddDateColumn | Generated from template ColumnArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColAddDateScalar | Generated from template ColumnArithmeticScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColAddIntervalDayTimeColumn | Generated from template DTIColumnArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColAddIntervalDayTimeScalar | Generated from template DTIColumnArithmeticDTIScalarNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColAddTimestampColumn | Generated from template DTIColumnArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColAddTimestampScalar | Generated from template DTIColumnArithmeticDTIScalarNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColEqualIntervalDayTimeScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColGreaterEqualIntervalDayTimeScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColGreaterIntervalDayTimeScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColLessEqualIntervalDayTimeScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColLessIntervalDayTimeScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColNotEqualIntervalDayTimeScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColSubtractIntervalDayTimeColumn | Generated from template DTIColumnArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeColSubtractIntervalDayTimeScalar | Generated from template DTIColumnArithmeticDTIScalarNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarAddDateColumn | Generated from template ScalarArithmeticColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarAddIntervalDayTimeColumn | Generated from template DTIScalarArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarAddTimestampColumn | Generated from template DTIScalarArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarEqualIntervalDayTimeColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarGreaterEqualIntervalDayTimeColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarGreaterIntervalDayTimeColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarLessEqualIntervalDayTimeColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarLessIntervalDayTimeColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarNotEqualIntervalDayTimeColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalDayTimeScalarSubtractIntervalDayTimeColumn | Generated from template DTIScalarArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColAddDateColumn | Generated from template IntervalColumnArithmeticDateTimeColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColAddDateScalar | Generated from template IntervalColumnArithmeticDateTimeScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColAddIntervalYearMonthColumn | Generated from template DTIColumnArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColAddIntervalYearMonthScalar | Generated from template DTIColumnArithmeticDTIScalarNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColAddTimestampColumn | Generated from template IntervalColumnArithmeticDateTimeColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColAddTimestampScalar | Generated from template IntervalColumnArithmeticDateTimeScalarWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColEqualIntervalYearMonthScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColGreaterEqualIntervalYearMonthScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColGreaterIntervalYearMonthScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColLessEqualIntervalYearMonthScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColLessIntervalYearMonthScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColNotEqualIntervalYearMonthScalar | Generated from template DTIColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColSubtractIntervalYearMonthColumn | Generated from template DTIColumnArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthColSubtractIntervalYearMonthScalar | Generated from template DTIColumnArithmeticDTIScalarNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarAddDateColumn | Generated from template IntervalScalarArithmeticDateTimeColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarAddIntervalYearMonthColumn | Generated from template DTIScalarArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarAddTimestampColumn | Generated from template IntervalScalarArithmeticDateTimeColumnWithConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarEqualIntervalYearMonthColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarGreaterEqualIntervalYearMonthColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarGreaterIntervalYearMonthColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarLessEqualIntervalYearMonthColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarLessIntervalYearMonthColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarNotEqualIntervalYearMonthColumn | Generated from template DTIScalarCompareColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntervalYearMonthScalarSubtractIntervalYearMonthColumn | Generated from template DTIScalarArithmeticDTIColumnNoConvert. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| IntObjectInspector | A IntObjectInspector inspects an Object representing an Integer. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| IntraQueryCorrelation | IntraQueryCorrelation records a sub-tree of the query plan tree which can be evaluated in a single MR job. | Class | org.apache.hadoop.hive.ql.optimizer.correlation | Apache Hive |
|
| IntString | | Class | org.apache.hadoop.hive.serde2.thrift.test | Apache Hive |
|
| InvalidColumn | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| InvalidColumnMappingException | | Class | org.apache.hadoop.hive.accumulo.columns | Apache Hive |
|
| InvalidInputException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| InvalidObjectException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| InvalidOperationException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| InvalidPartition | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| InvalidPartitionException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| InvalidTable | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| InvalidTableException | Generic exception class for Hive. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| InvalidTrasactionState | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| IOConstants | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| IOContext | IOContext basically contains the position information of the current key/value. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| IOPrepareCache | IOPrepareCache is used to cache pre-query io-related objects. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| IsNotNull | This expression evaluates to true if the given input columns is not null. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IsNull | This expression evaluates to true if the given input columns is null. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| IStringInExpr | Interface used for both filter and non-filter versions of IN to simplify VectorizationContext code. | Interface | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| ISupportStreamingModeForWindowing | A GenericUDAF mode that provides it results as a List to the WindowingTableFunction (so it is a | Interface | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| JarDelegator | Submit a job to the MapReduce queue. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| JavaAction | | Class | org.apache.hive.hcatalog.oozie | Apache Hive |
|
| JavaBinaryObjectInspector | Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaBooleanObjectInspector | A JavaBooleanObjectInspector inspects a Java Boolean Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaByteObjectInspector | A JavaByteObjectInspector inspects a Java Byte Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantBinaryObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantBooleanObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantByteObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantDateObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantDoubleObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantFloatObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantHiveCharObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantHiveDecimalObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantHiveVarcharObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantIntObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantLongObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantShortObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantStringObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaConstantTimestampObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaDataModel | Estimation of memory footprint of objectEnum Constant Summary | Class | org.apache.hadoop.hive.ql.util | Apache Hive |
|
| JavaDateObjectInspector | A JavaDateObjectInspector inspects a Java Date Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaDoubleObjectInspector | A JavaDoubleObjectInspector inspects a Java Double Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaFloatObjectInspector | A JavaFloatObjectInspector inspects a Java Float Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaHiveCharObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaHiveDecimalObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaHiveIntervalDayTimeObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaHiveIntervalYearMonthObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaHiveVarcharObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaIntObjectInspector | A JavaIntObjectInspector inspects a Java Integer Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaLongObjectInspector | A JavaLongObjectInspector inspects a Java Long Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaShortObjectInspector | A JavaShortObjectInspector inspects a Java Short Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaStringObjectInspector | A JavaStringObjectInspector inspects a Java String Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaTimestampObjectInspector | | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JavaUtils | | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| JavaVoidObjectInspector | A JavaVoidObjectInspector inspects a Java Void Object. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| JdbcColumn | | Class | org.apache.hive.jdbc | Apache Hive |
|
| JDBCStatsAggregator | | Class | org.apache.hadoop.hive.ql.stats.jdbc | Apache Hive |
|
| JDBCStatsPublisher | | Class | org.apache.hadoop.hive.ql.stats.jdbc | Apache Hive |
|
| JDBCStatsSetupConstants | | Class | org.apache.hadoop.hive.ql.stats.jdbc | Apache Hive |
|
| JDBCStatsUtils | | Class | org.apache.hadoop.hive.ql.stats.jdbc | Apache Hive |
|
| JdbcTable | | Class | org.apache.hive.jdbc | Apache Hive |
|
| JdbcUriParseException | | Class | org.apache.hive.jdbc | Apache Hive |
|
| JDOConnectionURLHook | JDOConnectURLHook is used to get the URL that JDO uses to connect to the database that stores the metastore data. | Interface | org.apache.hadoop.hive.metastore.hooks | Apache Hive |
|
| Jetty20SShims | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| Jetty23Shims | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| JettyShims | 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. | Interface | org.apache.hadoop.hive.shims | Apache Hive |
|
| JJTthrift_grammarState | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| Job | Interface for a Spark remote job. | Interface | org.apache.hive.spark.client | Apache Hive |
|
| JobContext | Holds runtime information about the job execution context. | Interface | org.apache.hive.spark.client | Apache Hive |
|
| JobDebugger | JobDebugger takes a RunningJob that has failed and grabs the top 4 failing tasks and outputs this information to the Hive CLI. | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| JobHandle | A handle to a submitted job. | Interface | org.apache.hive.spark.client | Apache Hive |
|
| JobItemBean | | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| JobMetricsListener | | Class | org.apache.hadoop.hive.ql.exec.spark.status.impl | Apache Hive |
|
| JobState | The persistent state of a job. | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| JobStateTracker | | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| JobSubmissionConstants | | Interface | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| JobTrackerState | enum JobTrackerStateEnum Constant Summary | Class | org.apache.hadoop.hive.service | Apache Hive |
|
| JobTrackerURLResolver | JobTrackerURLResolver. | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| JoinCond | Join conditions Descriptor implementation. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| JoinCondDesc | Join conditions Descriptor implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| JoinCondTypeCheckProcFactory | 1. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| JoinDesc | Join operator Descriptor implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| JoinOperator | Join operator implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| JoinReorder | hints to specify which tables are to be streamed and they are moved to have largest tag so that they are processed last. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| JoinType | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| JoinTypeCheckCtx | 1. | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| JoinUtil | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| JSONAddPartitionMessage | JSON implementation of AddPartitionMessage. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONAlterPartitionMessage | | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONAlterTableMessage | | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JsonBuilder | Helper class to build new json objects with new top level properties. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| JSONCreateDatabaseMessage | JSON Implementation of CreateDatabaseMessage. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONCreateTableMessage | JSON implementation of CreateTableMessage. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONDropDatabaseMessage | JSON implementation of DropDatabaseMessage. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONDropPartitionMessage | JSON implementation of DropPartitionMessage. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONDropTableMessage | JSON implementation of DropTableMessage. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONInsertMessage | JSON implementation of DropTableMessage. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONMessageDeserializer | MessageDeserializer implementation, for deserializing from JSON strings. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JSONMessageFactory | The JSON implementation of the MessageFactory. | Class | org.apache.hive.hcatalog.messaging.json | Apache Hive |
|
| JsonMetaDataFormatter | | Class | org.apache.hadoop.hive.ql.metadata.formatting | Apache Hive |
|
| JsonParser | | Interface | org.apache.hadoop.hive.common.jsonexplain | Apache Hive |
|
| JsonParserFactory | | Class | org.apache.hadoop.hive.common.jsonexplain | Apache Hive |
|
| JsonSerDe | | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| KerberosSaslHelper | | Class | org.apache.hive.service.auth | Apache Hive |
|
| KeyValueContainer | An eager key/value container that puts every row directly to output stream. | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| KeyValueInputMerger | A KeyValuesReader implementation that returns a sorted stream of key-values by doing a sorted merge of the key-value in LogicalInputs. | Class | org.apache.hadoop.hive.ql.exec.tez.tools | Apache Hive |
|
| KeyValuesInputMerger | A KeyValuesReader implementation that returns a sorted stream of key-values by doing a sorted merge of the key-value in LogicalInputs. | Class | org.apache.hadoop.hive.ql.exec.tez.tools | Apache Hive |
|
| KeyWrapper | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| KeyWrapperFactory | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| KryoSerializer | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| LateralViewForwardDesc | LateralViewForwardDesc. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LateralViewForwardOperator | LateralViewForwardOperator. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| LateralViewJoinDesc | LateralViewJoinDesc. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LateralViewJoinOperator | The lateral view join operator is used for FROM src LATERAL VIEW udtf(). | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| LauncherDelegator | | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| LaunchMapper | Note that this class is used in a different JVM than WebHCat server. | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| LazyAccumuloMap | A Hive Map created from some collection of Key-Values from one to many column families with one to many column qualifiers. | Class | org.apache.hadoop.hive.accumulo | Apache Hive |
|
| LazyAccumuloRow | Parses column tuples in each AccumuloHiveRow and creates Lazy objects for each field. | Class | org.apache.hadoop.hive.accumulo | Apache Hive |
|
| LazyArray | LazyArray stores an array of Lazy Objects. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyBinary | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyBinaryArray | LazyBinaryArray is serialized as follows: start A b b b b b b end bytes | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryBinary | | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryBoolean | LazyBinaryObject for boolean which takes one byte Part of the code is adapted from Apache Harmony Project. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryByte | LazyBinaryObject for byte which takes one byte. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryColumnarSerDe | LazyBinaryColumnarSerDe. | Class | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| LazyBinaryColumnarStruct | | Class | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| LazyBinaryDate | A LazyBinaryObject that encodes a java. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryDeserializeRead | | Class | org.apache.hadoop.hive.serde2.lazybinary.fast | Apache Hive |
|
| LazyBinaryDouble | LazyBinaryObject for double which takes eight bytes. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryFactory | | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryFloat | LazyBinaryObject for float which takes four bytes. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryHiveChar | | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryHiveDecimal | | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryHiveIntervalDayTime | LazyBinaryHiveIntervalDayTime A LazyBinaryObject that encodes a HiveIntervalDayTime | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryHiveIntervalYearMonth | LazyBinaryHiveIntervalYearMonth A LazyBinaryObject that encodes a HiveIntervalYearMonth | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryHiveVarchar | | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryInteger | LazyBinaryObject for integer which is serialized as VInt. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryListObjectInspector | ObjectInspector for LazyBinaryList. | Class | org.apache.hadoop.hive.serde2.lazybinary.objectinspector | Apache Hive |
|
| LazyBinaryLong | LazyBinaryObject for long which stores as VLong. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryMap | LazyBinaryMap is serialized as follows: start A b c b c b c end bytes[] . | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryMapObjectInspector | ObjectInspector for LazyBinaryMap. | Class | org.apache.hadoop.hive.serde2.lazybinary.objectinspector | Apache Hive |
|
| LazyBinaryNonPrimitive | LazyBinaryNonPrimitive. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryObject | LazyBinaryObject stores an object in a binary format in a byte[]. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryObjectInspector | | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyBinaryObjectInspectorFactory | ObjectInspectorFactory is the primary way to create new ObjectInspector SerDe classes should call the static functions in this library to create an | Class | org.apache.hadoop.hive.serde2.lazybinary.objectinspector | Apache Hive |
|
| LazyBinaryPrimitive | Defines a LazyBinaryPrimitive. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinarySerDe | The LazyBinarySerDe class combines the lazy property of LazySimpleSerDe class and the binary property of BinarySortable class. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinarySerializeWrite | | Class | org.apache.hadoop.hive.serde2.lazybinary.fast | Apache Hive |
|
| LazyBinaryShort | LazyBinaryObject for short which takes two bytes. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryString | The serialization of LazyBinaryString is very simple: start A end bytes[] | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryStruct | LazyBinaryStruct is serialized as follows: start A B A B A B end bytes[] | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryStructObjectInspector | ObjectInspector for LazyBinaryStruct. | Class | org.apache.hadoop.hive.serde2.lazybinary.objectinspector | Apache Hive |
|
| LazyBinaryTimestamp | A LazyBinaryObject that encodes a java. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryUnion | LazyBinaryUnion is serialized as follows: start TAG FIELD end bytes[] | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryUnionObjectInspector | ObjectInspector for LazyBinaryUnion. | Class | org.apache.hadoop.hive.serde2.lazybinary.objectinspector | Apache Hive |
|
| LazyBinaryUtils | | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBinaryVoid | LazyBinaryVoid for NULL which is a placeholder class and it does not need to store any data. | Class | org.apache.hadoop.hive.serde2.lazybinary | Apache Hive |
|
| LazyBoolean | LazyObject for storing a value of boolean. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyBooleanObjectInspector | A WritableBooleanObjectInspector inspects a BooleanWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyByte | LazyObject for storing a value of Byte. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyByteObjectInspector | A WritableByteObjectInspector inspects a ByteWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyDate | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyDateObjectInspector | A WritableDateObjectInspector inspects a DateWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyDecompressionCallback | Used to call back lazy decompression process. | Interface | org.apache.hadoop.hive.serde2.columnar | Apache Hive |
|
| LazyDioBoolean | LazyBooleanBinary for storing a boolean value as an BooleanWritable. | Class | org.apache.hadoop.hive.serde2.lazydio | Apache Hive |
|
| LazyDioByte | LazyByteBinary for storing a byte value as a ByteWritable. | Class | org.apache.hadoop.hive.serde2.lazydio | Apache Hive |
|
| LazyDioDouble | LazyDoubleBinary for storing a double value as a DoubleWritable. | Class | org.apache.hadoop.hive.serde2.lazydio | Apache Hive |
|
| LazyDioFloat | LazyFloatBinary for storing a float value as a FloatWritable. | Class | org.apache.hadoop.hive.serde2.lazydio | Apache Hive |
|
| LazyDioInteger | LazyIntegerBinary for storing an int value as an IntWritable. | Class | org.apache.hadoop.hive.serde2.lazydio | Apache Hive |
|
| LazyDioLong | LazyLongBinary for storing a long value as a LongWritable. | Class | org.apache.hadoop.hive.serde2.lazydio | Apache Hive |
|
| LazyDioShort | LazyShortBinary for storing a short value as a ShortWritable. | Class | org.apache.hadoop.hive.serde2.lazydio | Apache Hive |
|
| LazyDouble | LazyObject for storing a value of Double. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyDoubleObjectInspector | A WritableDoubleObjectInspector inspects a DoubleWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyFactory | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyFloat | LazyObject for storing a value of Double. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyFloatObjectInspector | A FloatObjectInspector inspects a FloatWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyHBaseCellMap | LazyHBaseCellMap refines LazyMap with HBase column mapping. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| LazyHBaseRow | LazyObject for storing an HBase row. | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| LazyHCatRecord | An implementation of HCatRecord that wraps an Object returned by a SerDe and an ObjectInspector. | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| LazyHiveChar | LazyObject for storing a value of HiveChar. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyHiveCharObjectInspector | | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyHiveDecimal | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyHiveDecimalObjectInspector | | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyHiveIntervalDayTime | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyHiveIntervalDayTimeObjectInspector | | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyHiveIntervalYearMonth | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyHiveIntervalYearMonthObjectInspector | | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyHiveVarchar | LazyObject for storing a value of HiveVarchar. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyHiveVarcharObjectInspector | | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyInteger | LazyObject for storing a value of Integer. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyIntObjectInspector | A WritableIntObjectInspector inspects a IntWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyListObjectInspector | LazyListObjectInspector works on array data that is stored in LazyArray. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector | Apache Hive |
|
| LazyLong | LazyObject for storing a value of Long. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyLongObjectInspector | A WritableLongObjectInspector inspects a LongWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyMap | LazyMap stores a map of Primitive LazyObjects to LazyObjects. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyMapObjectInspector | LazyMapObjectInspector works on struct data that is stored in LazyStruct. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector | Apache Hive |
|
| LazyNonPrimitive | LazyPrimitive stores a primitive Object in a LazyObject. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyObject | LazyObject stores an object in a range of bytes in a byte[]. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyObjectBase | | Interface | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyObjectInspectorFactory | ObjectInspectorFactory is the primary way to create new ObjectInspector SerDe classes should call the static functions in this library to create an | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector | Apache Hive |
|
| LazyObjectInspectorParameters | | Interface | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyObjectInspectorParametersImpl | | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyPrimitive | LazyPrimitive stores a primitive Object in a LazyObject. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyPrimitiveObjectInspectorFactory | LazyPrimitiveObjectInspectorFactory is the primary way to create new ObjectInspector instances. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazySerDeParameters | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyShort | LazyObject for storing a value of Short. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyShortObjectInspector | A WritableShortObjectInspector inspects a ShortWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazySimpleDeserializeRead | | Class | org.apache.hadoop.hive.serde2.lazy.fast | Apache Hive |
|
| LazySimpleSerDe | LazySimpleSerDe can be used to read the same data format as MetadataTypedColumnsetSerDe and TCTLSeparatedProtocol. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazySimpleSerializeWrite | | Class | org.apache.hadoop.hive.serde2.lazy.fast | Apache Hive |
|
| LazySimpleStructObjectInspector | LazySimpleStructObjectInspector works on struct data that is stored in The names of the struct fields and the internal structure of the struct | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector | Apache Hive |
|
| LazyString | LazyObject for storing a value of String. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyStringObjectInspector | A WritableStringObjectInspector inspects a Text Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyStruct | LazyObject for storing a struct. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyTimestamp | Serializes and deserializes a Timestamp in the JDBC timestamp format YYYY-MM-DD HH:MM:SS. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyTimestampObjectInspector | | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LazyUnion | LazyObject for storing a union. | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyUnionObjectInspector | LazyUnionObjectInspector works on union data that is stored in LazyUnion. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector | Apache Hive |
|
| LazyUtils | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyVoid | | Class | org.apache.hadoop.hive.serde2.lazy | Apache Hive |
|
| LazyVoidObjectInspector | A WritableVoidObjectInspector inspects a NullWritable Object. | Class | org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive | Apache Hive |
|
| LBExprProcCtx | The processor context for list bucketing pruner. | Class | org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | Apache Hive |
|
| LBExprProcFactory | Expression processor factory for list bucketing pruning. | Class | org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | Apache Hive |
|
| LBOpPartitionWalkerCtx | | Class | org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | Apache Hive |
|
| LBOpWalkerCtx | Context used by list bucketing to walk operator trees to generate expression tree. | Class | org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | Apache Hive |
|
| LBPartitionProcFactory | Walk through top operators in tree to find all partitions. | Class | org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | Apache Hive |
|
| LBProcFactory | Operator factory for list bucketing pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators. | Class | org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | Apache Hive |
|
| LdapAuthenticationProviderImpl | | Class | org.apache.hive.service.auth | Apache Hive |
|
| LeadLagInfo | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| LeafFilterFactory | | Class | org.apache.hadoop.hive.ql.io.parquet | Apache Hive |
|
| LeftmostBigTableSelectorForAutoSMJ | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| LessThan | Wraps call to lessThan over PrimitiveComparison instance. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| LessThanOrEqual | Wraps call to lessThanOrEqual over PrimitiveComparison instance. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| Like | Wraps call to like over PrimitiveComparison instance. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| LimitDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LimitOperator | Limit operator implementation Limits the number of rows to be passed on. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| LimitPushdownOptimizer | Make RS calculate top-K selection for limit clause. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| LineageCtx | This class contains the lineage context that is passed while walking the operator tree in Lineage. | Class | org.apache.hadoop.hive.ql.optimizer.lineage | Apache Hive |
|
| LineageInfo | This class contains the lineage information that is passed to the PreExecution hook. | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| LineageInfo | This class prints out the lineage info. | Class | org.apache.hadoop.hive.ql.tools | Apache Hive |
|
| LineageState | LineageState. | Class | org.apache.hadoop.hive.ql.session | Apache Hive |
|
| LinearExtrapolatePartStatus | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| ListBucketingCtx | Context for list bucketing. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ListBucketingPruner | The transformation step that does list bucketing pruning. | Class | org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | Apache Hive |
|
| ListBucketingPrunerUtils | Utility for list bucketing prune. | Class | org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | Apache Hive |
|
| ListDelegator | List jobs owned by a user. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| ListenerEvent | Base class for all the events which are defined for metastore. | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| ListObjectInspector | ListObjectInspector. | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ListObjectsEqualComparer | Compare two list of objects. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ListResourceProcessor | | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| ListSinkDesc | description for ListSinkOperator, just for explain result. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ListSinkOperator | For fetch task with operator tree, row read from FetchOperator is processed via operator tree and finally arrives to this operator. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ListTypeInfo | A List Type has homogeneous elements. | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| LoadDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LoadFileDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LoadMultiFilesDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LoadPartitionDoneEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| LoadSemanticAnalyzer | LoadSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| LoadTableDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LocalHiveSparkClient | LocalSparkClient submit Spark job in local driver, it's responsible for build spark client environment and execute spark work. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| LocalMapJoinProcFactory | Node processor factory for map join resolver. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| LocalSparkJobMonitor | LocalSparkJobMonitor monitor a single Spark job status in a loop until job finished/failed/killed. | Class | org.apache.hadoop.hive.ql.exec.spark.status | Apache Hive |
|
| LocalSparkJobRef | | Class | org.apache.hadoop.hive.ql.exec.spark.status.impl | Apache Hive |
|
| LocalSparkJobStatus | | Class | org.apache.hadoop.hive.ql.exec.spark.status.impl | Apache Hive |
|
| LockComponent | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| LockComponentBuilder | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| LockDatabaseDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LockException | Exception from lock manager. | Class | org.apache.hadoop.hive.ql.lockmgr | Apache Hive |
|
| LockLevel | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| LockRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| LockRequestBuilder | Builder class to make constructing LockRequest easier. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| LockResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| LockState | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| LockTableDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| LockType | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| LogDivertAppender | An Appender to divert logs from individual threads to the LogObject they belong to. | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| LogRetriever | | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| LogUtils | Utilities common to logging operations. | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| LongColAddDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColAddDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColAddLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColAddLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColDivideDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColDivideDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColDivideLongColumn | This operation is handled as a special case because Hive long/long division returns double. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| LongColDivideLongScalar | This operation is handled as a special case because Hive long/long division returns double. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| LongColEqualDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColEqualDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColEqualLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColEqualLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColGreaterDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColGreaterDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColGreaterEqualDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColGreaterEqualDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColGreaterEqualLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColGreaterEqualLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColGreaterLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColGreaterLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColLessDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColLessDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColLessEqualDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColLessEqualDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColLessEqualLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColLessEqualLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColLessLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColLessLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColModuloDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColModuloDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColModuloLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColModuloLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColMultiplyDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColMultiplyDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColMultiplyLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColMultiplyLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColNotEqualDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColNotEqualDoubleScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColNotEqualLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColNotEqualLongScalar | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColSubtractDoubleColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColSubtractDoubleScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColSubtractLongColumn | Generated from template ColumnArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColSubtractLongScalar | Generated from template ColumnArithmeticScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongColumnInList | Output a boolean value indicating if a column is IN a list of constants. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| LongColumnStatsData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| LongColumnVector | This class represents a nullable int column vector. | Class | org.apache.hadoop.hive.ql.exec.vector | Apache Hive |
|
| LongColUnaryMinus | Generated from template ColumnUnaryMinus. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongCompare | Set of comparison operations over a long constant. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| LongNumDistinctValueEstimator | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| LongObjectInspector | A LongObjectInspector inspects an Object representing a Long. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| LongScalarAddDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarAddLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarDivideDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarDivideLongColumn | This operation is handled as a special case because Hive long/long division returns double. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| LongScalarEqualDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarEqualLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarEqualTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarGreaterDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarGreaterEqualDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarGreaterEqualLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarGreaterEqualTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarGreaterLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarGreaterTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarLessDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarLessEqualDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarLessEqualLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarLessEqualTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarLessLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarLessTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarModuloDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarModuloLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarMultiplyDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarMultiplyLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarNotEqualDoubleColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarNotEqualLongColumn | Generated from template ColumnCompareScalar. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarNotEqualTimestampColumn | Generated from template ScalarCompareTimestampColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarSubtractDoubleColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongScalarSubtractLongColumn | Generated from template ScalarArithmeticColumn. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| LongToStringUnaryUDF | This is a superclass for unary long functions returning strings that operate directly on the input and set the output. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| LoopingByteArrayInputStream | LoopingByteArrayInputStream. | Class | org.apache.hadoop.hive.conf | Apache Hive |
|
| MacroSemanticAnalyzer | MacroSemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| Main | The main executable that starts up and runs the Server. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| MapAggrMemErrorHeuristic | Detects out-of-memory errors when hash tables in map-based aggregation group by queries take up too much memory. | Class | org.apache.hadoop.hive.ql.exec.errors | Apache Hive |
|
| MapBuilder | Helper class to build Maps consumed by the JSON formatter. | Class | org.apache.hadoop.hive.ql.metadata.formatting | Apache Hive |
|
| MapEqualComparer | | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| MapInput | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| MapJoinBytesTableContainer | Table container that serializes keys and values using LazyBinarySerDe into BytesBytesMultiHashMap, with very low memory overhead. | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinDesc | Map Join operator Descriptor implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| MapJoinEagerRowContainer | | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinFactory | Operator factory for MapJoin processing. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| MapJoinKey | The base class for MapJoinKey. | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinKeyObject | | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinMemoryExhaustionException | | Class | org.apache.hadoop.hive.ql.exec.mapjoin | Apache Hive |
|
| MapJoinMemoryExhaustionHandler | Handles the logic around deciding when to throw an MapJoinMemoryExhaustionException for HashTableSinkOperator. | Class | org.apache.hadoop.hive.ql.exec.mapjoin | Apache Hive |
|
| MapJoinObjectSerDeContext | | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinOperator | Map side Join operator implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| MapJoinPersistableTableContainer | | Interface | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinProcessor | map-joins and during this optimization, all user specified map joins are converted to MapJoins - the reduce sink operator above the join are converted to map sink operators. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| MapJoinResolver | An implementation of PhysicalPlanResolver. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| MapJoinRowContainer | | Interface | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinTableContainer | | Interface | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinTableContainerDirectAccess | | Interface | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapJoinTableContainerSerDe | | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| MapObjectInspector | | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| MapOperator | Map operator. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| Mapper | | Interface | org.apache.hadoop.hive.contrib.mr | Apache Hive |
|
| MapRecordProcessor | Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| MapRecordSource | Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| MapredContext | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| MapredLocalTask | MapredLocalTask represents any local work (i. | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| MapredLocalWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| MapredParquetInputFormat | A Parquet InputFormat for Hive (with the deprecated package mapred) NOTE: With HIVE-9235 we removed "implements VectorizedParquetInputFormat" since all data types | Class | org.apache.hadoop.hive.ql.io.parquet | Apache Hive |
|
| MapredParquetOutputFormat | | Class | org.apache.hadoop.hive.ql.io.parquet | Apache Hive |
|
| MapRedStats | A data structure to keep one mapreduce's stats: number of mappers, number of reducers, accumulative CPU time and whether it | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| MapRedTask | Extension of ExecDriver: - can optionally spawn a map-reduce task from a separate jvm | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| MapReduceCompiler | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| MapredWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| MapTezProcessor | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| MapTran | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| MapTypeInfo | A Map Type has homogeneous keys and homogeneous values. | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| MapWork | MapWork represents all the information used to run a map task on the cluster. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| MatchPath | return rows that meet a specified pattern. | Class | org.apache.hadoop.hive.ql.udf.ptf | Apache Hive |
|
| MathExpr | Math expression evaluation helper functions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| MathFuncDoubleToDouble | constant argument(s)) and returns long. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| MathFuncLongToDouble | constant argument(s)) and returns long. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| MathFuncLongToLong | constant argument(s)) and returns long. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| MaxByteArrayOutputStream | An output stream that will only accept the first N bytes of data. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| MColumnDescriptor | A wrapper around a list of columns. | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MDatabase | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MDBPrivilege | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MDelegationToken | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MegaStruct | | Class | org.apache.hadoop.hive.serde2.thrift.test | Apache Hive |
|
| MemoryTokenStore | Default in-memory token store implementation. | Class | org.apache.hadoop.hive.thrift | Apache Hive |
|
| MergeFileInputFormat | | Class | org.apache.hadoop.hive.ql.io.merge | Apache Hive |
|
| MergeFileMapper | Mapper for fast file merging of ORC and RC files. | Class | org.apache.hadoop.hive.ql.io.merge | Apache Hive |
|
| MergeFileOutputFormat | | Class | org.apache.hadoop.hive.ql.io.merge | Apache Hive |
|
| MergeFileRecordProcessor | Record processor for fast merging of files. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| MergeFileTask | Task for fast merging of ORC and RC files. | Class | org.apache.hadoop.hive.ql.io.merge | Apache Hive |
|
| MergeFileTezProcessor | Tez processor for fast file merging. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| MergeFileWork | | Class | org.apache.hadoop.hive.ql.io.merge | Apache Hive |
|
| MergeJoinProc | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| MergeJoinWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| MessageDeserializer | Interface for converting HCat events from String-form back to HCatEventMessage instances. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| MessageFactory | Abstract Factory for the construction of HCatalog message instances. | Class | org.apache.hive.hcatalog.messaging | Apache Hive |
|
| MessagingUtils | Helper Utility to assist consumers of HCat Messages in extracting message-content from JMS messages. | Class | org.apache.hive.hcatalog.messaging.jms | Apache Hive |
|
| Metadata | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| MetaDataExportListener | This class listens for drop events and, if set, exports the table's metadata as JSON to the trash of the user performing the drop | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| MetaDataFormatter | Interface to format table and index information. | Interface | org.apache.hadoop.hive.ql.metadata.formatting | Apache Hive |
|
| MetaDataFormatUtils | This class provides methods to format table and index information. | Class | org.apache.hadoop.hive.ql.metadata.formatting | Apache Hive |
|
| MetadataListStructObjectInspector | StructObjectInspector works on struct data that is stored as a Java List or Java Array object. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| MetadataOnlyOptimizer | MetadataOnlyOptimizer determines to which TableScanOperators "metadata only" optimization can be applied. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| MetadataOperation | | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| MetaDataPrettyFormatUtils | This class provides methods to format the output of DESCRIBE PRETTY in a human-readable way. | Class | org.apache.hadoop.hive.ql.metadata.formatting | Apache Hive |
|
| MetadataReader | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| MetadataTypedColumnsetSerDe | MetadataTypedColumnsetSerDe. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| MetaException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| MetaStoreAuthzAPIAuthorizerEmbedOnly | | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| MetaStoreEndFunctionContext | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreEndFunctionListener | This abstract class needs to be extended to provide implementation of actions that need to be performed when a function ends. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreEventListener | This abstract class needs to be extended to provide implementation of actions that needs to be performed when a particular event occurs on a metastore. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreFilterHook | Metadata filter hook for metastore client. | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreFS | | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreInit | MetaStoreInit defines functions to init/update MetaStore connection url. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreInitContext | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreInitListener | This abstract class needs to be extended to provide implementation of actions that needs to be performed when HMSHandler is initialized | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStorePreEventListener | This abstract class needs to be extended to provide implementation of actions that needs to be performed before a particular event occurs on a metastore. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreSchemaInfo | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreThread | A thread that runs in the metastore, separate from the threads in the thrift service. | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| MetaStoreUtils | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| Metrics | Metrics Subsystem - allows exposure of a number of named parameters/counters via jmx, intended to be used as a static subsystem | Class | org.apache.hadoop.hive.common.metrics | Apache Hive |
|
| Metrics | Metrics tracked during the execution of a job. | Class | org.apache.hive.spark.client.metrics | Apache Hive |
|
| MetricsCollection | Provides metrics collected for a submitted job. | Class | org.apache.hive.spark.client | Apache Hive |
|
| MetricsMBean | | Interface | org.apache.hadoop.hive.common.metrics | Apache Hive |
|
| MetricsMBeanImpl | | Class | org.apache.hadoop.hive.common.metrics | Apache Hive |
|
| MFieldSchema | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MFunction | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MGlobalPrivilege | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MIndex | Represents hive's index definition. | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MiniSparkOnYARNCluster | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| MiniStruct | | Class | org.apache.hadoop.hive.serde2.thrift.test | Apache Hive |
|
| MMasterKey | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MNotificationLog | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MNotificationNextId | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MOrder | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MoveTask | MoveTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| MoveWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| MPartition | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MPartitionColumnPrivilege | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MPartitionColumnStatistics | MPartitionColumnStatistics - Represents Hive's partiton level Column Statistics Description. | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MPartitionEvent | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MPartitionPrivilege | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MPrincipalDesc | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MResourceUri | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MRole | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MRoleMap | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MsckDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| MSerDeInfo | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MStorageDescriptor | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MStringList | It represents data structure of string list. | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MTable | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MTableColumnPrivilege | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MTableColumnStatistics | MTableColumnStatistics - Represents Hive's Column Statistics Description. | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MTablePrivilege | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MType | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MultiDelimitSerDe | This SerDe allows user to use multiple characters as the field delimiter for a table. | Class | org.apache.hadoop.hive.contrib.serde2 | Apache Hive |
|
| MultiOutputFormat | The MultiOutputFormat class simplifies writing output data to multiple Multiple output formats can be defined each with its own | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| Murmur3 | Murmur3 is successor to Murmur2 fast non-crytographic hash algorithms. | Class | org.apache.hive.common.util | Apache Hive |
|
| MuxDesc | Mux operator descriptor implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| MuxOperator | MuxOperator is used in the Reduce side of MapReduce jobs optimized by Correlation Optimizer. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| MVersionTable | | Class | org.apache.hadoop.hive.metastore.model | Apache Hive |
|
| MyEnum | | Class | org.apache.hadoop.hive.serde2.thrift.test | Apache Hive |
|
| NanoTime | Provides a wrapper representing a parquet-timestamp, with methods to convert to and from binary. | Class | org.apache.hadoop.hive.ql.io.parquet.timestamp | Apache Hive |
|
| NanoTimeUtils | Utilities for converting from java. | Class | org.apache.hadoop.hive.ql.io.parquet.timestamp | Apache Hive |
|
| NGramEstimator | A generic, re-usable n-gram estimation class that supports partial aggregations. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| Node | This interface defines the functions needed by the walkers and dispatchers. | Interface | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| Node | | Interface | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| NodeProcessor | Base class for processing operators which is no-op. | Interface | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| NodeType | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| NodeUtils | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| NoMatchingMethodException | Exception thrown by the UDF and UDAF method resolvers in case no matching methodSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| NonBlockingOpDeDupProc | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| NonSyncByteArrayInputStream | A thread-not-safe version of ByteArrayInputStream, which removes all synchronized modifiers. | Class | org.apache.hadoop.hive.common.io | Apache Hive |
|
| NonSyncByteArrayOutputStream | A thread-not-safe version of ByteArrayOutputStream, which removes all synchronized modifiers. | Class | org.apache.hadoop.hive.common.io | Apache Hive |
|
| NonSyncDataInputBuffer | A thread-not-safe version of Hadoop's DataInputBuffer, which removes all synchronized modifiers. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| NonSyncDataOutputBuffer | A thread-not-safe version of Hadoop's DataOutputBuffer, which removes all synchronized modifiers. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| Noop | | Class | org.apache.hadoop.hive.ql.udf.ptf | Apache Hive |
|
| NoopCommand | This class is there to help testing, and to help initial development and will be the default Command for NoopReplicationTask | Class | org.apache.hive.hcatalog.api.repl.commands | Apache Hive |
|
| NoopReplicationTask | Noop replication task - a replication task that is actionable, does not need any further info, and returns NoopCommands. | Class | org.apache.hive.hcatalog.api.repl | Apache Hive |
|
| NoopStreaming | | Class | org.apache.hadoop.hive.ql.udf.ptf | Apache Hive |
|
| NoopWithMap | | Class | org.apache.hadoop.hive.ql.udf.ptf | Apache Hive |
|
| NoopWithMapStreaming | | Class | org.apache.hadoop.hive.ql.udf.ptf | Apache Hive |
|
| NoSuchCompareOpException | | Class | org.apache.hadoop.hive.accumulo.predicate | Apache Hive |
|
| NoSuchLockException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| NoSuchObjectException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| NoSuchPrimitiveComparisonException | Used when a PrimitiveComparison was specified but one with that name cannot be foundSee Also:Serialized Form | Class | org.apache.hadoop.hive.accumulo.predicate | Apache Hive |
|
| NoSuchTxnException | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| NotAuthorizedException | Simple "user not found" type exception. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| NotCol | Evaluates the boolean complement of the input. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| NotEqual | Wraps call to isEqual over PrimitiveComparison instance and returns the negation. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| NotFoundException | Simple not found exception. | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| NotificationEvent | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| NotificationEventRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| NotificationEventResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| NotificationListener | MetaStoreEventListener It sends message on two type of topics. | Class | org.apache.hive.hcatalog.listener | Apache Hive |
|
| NullRecordReader | An empty record reader. | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| NullRowsInputFormat | NullRowsInputFormat outputs null rows, maximum 100. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| NullScanOptimizer | This optimizer attempts following two optimizations: 1. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| NullScanTaskDispatcher | Iterate over all tasks one by one and removes all input paths from task if conditions as defined in rules match. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| NullSplit | | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| NullStructSerDe | | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| NullUtil | Utility functions to handle null propagation. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| NumDistinctValueEstimator | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| NumericHistogram | A generic, re-usable histogram class that supports partial aggregations. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| NumericOpMethodResolver | The class implements the method resolution for operators like (+, -, *, %). | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| NumericUDAF | Base class of numeric UDAFs like sum and avg which need a NumericUDAFEvaluatorResolver. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| NumericUDAFEvaluatorResolver | Resolver for Numeric UDAFs like sum and avg. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ObjectCache | ObjectCache. | Class | org.apache.hadoop.hive.ql.exec.mr | Apache Hive |
|
| ObjectCache | ObjectCache. | Interface | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ObjectCache | ObjectCache. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| ObjectCacheFactory | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ObjectContainer | An eager object container that puts every row directly to output stream. | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| ObjectInspector | ObjectInspector helps us to look into the internal structure of a complex A (probably configured) ObjectInspector instance stands for a specific type | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ObjectInspectorConverters | ObjectInspectorConverters. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ObjectInspectorFactory | ObjectInspectorFactory is the primary way to create new ObjectInspector SerDe classes should call the static functions in this library to create an | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ObjectInspectorUtils | ObjectInspectorFactory is the primary way to create new ObjectInspector SerDe classes should call the static functions in this library to create an | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ObjectNotFoundException | This exception is thrown when a Database, Table or Partition specified in an HCatalog query is not found. | Class | org.apache.hive.hcatalog.api | Apache Hive |
|
| ObjectPair | | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| ObjectStore | This class is the interface between the application logic and the database store that contains the objects. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| OneNullRowInputFormat | OneNullRowInputFormat outputs one null row. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| Op | | Class | org.apache.hadoop.hive.common.jsonexplain.tez | Apache Hive |
|
| OpenCSVSerde | OpenCSVSerde use opencsv to deserialize CSV format. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| OpenTxnRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| OpenTxnsResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| Operation | | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| Operation2Privilege | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| OperationHandle | | Class | org.apache.hive.service.cli | Apache Hive |
|
| OperationLog | OperationLog wraps the actual operation log file, and provides interface for accessing, reading, writing, and removing the file. | Class | org.apache.hadoop.hive.ql.session | Apache Hive |
|
| OperationManager | | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| OperationState | | Class | org.apache.hive.service.cli | Apache Hive |
|
| OperationStatus | | Class | org.apache.hive.service.cli | Apache Hive |
|
| OperationType | | Class | org.apache.hive.service.cli | Apache Hive |
|
| Operator | Base operator implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| Operator | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| OperatorDesc | | Interface | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| OperatorFactory | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| OperatorType | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| OperatorUtils | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| OpParseContext | that may be needed by an operator. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| OpProcFactory | Operator factory for the rule processors for lineage. | Class | org.apache.hadoop.hive.ql.optimizer.lineage | Apache Hive |
|
| OpProcFactory | Operator factory for partition pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators. | Class | org.apache.hadoop.hive.ql.optimizer.ppr | Apache Hive |
|
| OpProcFactory | Operator factory for predicate pushdown processing of operator graph Each operator determines the pushdown predicates by walking the expression tree. | Class | org.apache.hadoop.hive.ql.ppd | Apache Hive |
|
| Optimizer | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| OptimizeSparkProcContext | OptimizeSparkProcContext. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| OptimizeTezProcContext | OptimizeTezProcContext. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| OptionsProcessor | | Class | org.apache.hadoop.hive.cli | Apache Hive |
|
| OpTraits | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| OpTraitsRulesProcFactory | | Class | org.apache.hadoop.hive.ql.optimizer.metainfo.annotation | Apache Hive |
|
| OpWalkerCtx | Context class for operator tree walker for partition pruner. | Class | org.apache.hadoop.hive.ql.optimizer.ppr | Apache Hive |
|
| OpWalkerInfo | Context class for operator walker of predicate pushdown. | Class | org.apache.hadoop.hive.ql.ppd | Apache Hive |
|
| OrcFile | Contains factory methods to read or write ORC files. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcFileKeyWrapper | Key for OrcFileMergeMapper task. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcFileMergeDesc | ORC fast file merge operator descriptor. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| OrcFileMergeOperator | Fast file merge operator for ORC files. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ORCFileStorageFormatDescriptor | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| OrcFileStripeMergeInputFormat | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcFileStripeMergeRecordReader | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcFileValueWrapper | Value for OrcFileMergeMapper. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcInputFormat | A MapReduce/Hive input format for ORC files. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcNewInputFormat | An InputFormat for ORC files. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcNewOutputFormat | An OutputFormat that writes ORC files. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcNewSplit | OrcFileSplit. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcOutputFormat | A Hive OutputFormat for ORC files. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcProto | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcRawRecordMerger | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcRecordUpdater | A RecordUpdater where the files are stored as ORC. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcSerde | A serde class for ORC. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcSplit | OrcFileSplit. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcStruct | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| OrcUtils | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| Order | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| OrderDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| OrderExpressionDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| Output | It's the responsibility of the caller to ensure the output is in the correct format (contains the correct number of columns, etc. | Interface | org.apache.hadoop.hive.contrib.mr | Apache Hive |
|
| OutputFile | | Class | org.apache.hive.beeline | Apache Hive |
|
| OutputJobInfo | The class used to serialize and store the output related informationSee Also:Serialized Form | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| Pair | Copy of C++ STL pair container. | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| PamAuthenticationProviderImpl | | Class | org.apache.hive.service.auth | Apache Hive |
|
| ParquetByteInspector | The ParquetByteInspector can inspect both ByteWritables and IntWritables into bytes. | Class | org.apache.hadoop.hive.ql.io.parquet.serde.primitive | Apache Hive |
|
| ParquetFileStorageFormatDescriptor | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| ParquetHiveArrayInspector | The ParquetHiveArrayInspector will inspect an ArrayWritable, considering it as an Hive array. | Class | org.apache.hadoop.hive.ql.io.parquet.serde | Apache Hive |
|
| ParquetHiveRecord | This class wraps the object and object inspector that will be used later in DataWritableWriter class to get the object values. | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| ParquetHiveSerDe | | Class | org.apache.hadoop.hive.ql.io.parquet.serde | Apache Hive |
|
| ParquetPrimitiveInspectorFactory | The ParquetPrimitiveInspectorFactory allows us to be sure that the same object is inspected by the same inspector. | Class | org.apache.hadoop.hive.ql.io.parquet.serde.primitive | Apache Hive |
|
| ParquetRecordReaderWrapper | | Class | org.apache.hadoop.hive.ql.io.parquet.read | Apache Hive |
|
| ParquetRecordWriterWrapper | | Class | org.apache.hadoop.hive.ql.io.parquet.write | Apache Hive |
|
| ParquetShortInspector | The ParquetShortInspector can inspect both ShortWritables and IntWritables into shorts. | Class | org.apache.hadoop.hive.ql.io.parquet.serde.primitive | Apache Hive |
|
| ParquetStringInspector | The ParquetStringInspector inspects a BinaryWritable to give a Text or String. | Class | org.apache.hadoop.hive.ql.io.parquet.serde.primitive | Apache Hive |
|
| ParseContext | Parse Context: The current parse context. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ParseDriver | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ParseException | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ParseException | This exception is thrown when parse errors are encountered. | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| ParseUtils | Library of utility functions used in the parse code. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| PartExprEvalUtils | | Class | org.apache.hadoop.hive.ql.optimizer.ppr | Apache Hive |
|
| PartialScanMapper | It reads through block header and aggregates statistics at the end. | Class | org.apache.hadoop.hive.ql.io.rcfile.stats | Apache Hive |
|
| PartialScanTask | This task handles RCFile statics calculation via partial scan. | Class | org.apache.hadoop.hive.ql.io.rcfile.stats | Apache Hive |
|
| PartialScanWork | | Class | org.apache.hadoop.hive.ql.io.rcfile.stats | Apache Hive |
|
| PartInfo | The Class used to serialize the partition information read from the metadata server that maps to a partition. | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| Partition | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| Partition | A Hive Table Partition: is a fundamental storage unit within a Table. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| PartitionConditionRemover | The transformation step that does partition condition remover. | Class | org.apache.hadoop.hive.ql.optimizer.pcr | Apache Hive |
|
| PartitionCreationFailed | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| PartitionDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| PartitionDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| PartitionDesc | A description of the partition to create. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| PartitionDropOptions | Class to generalize the switches for dropPartitions(). | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| PartitionedTableFunctionDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| PartitionEventType | enum PartitionEventTypeEnum Constant Summary | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PartitionExpressionForMetastore | The basic implementation of PartitionExpressionProxy that uses ql package classes. | Class | org.apache.hadoop.hive.ql.optimizer.ppr | Apache Hive |
|
| PartitionExpressionProxy | The proxy interface that metastore uses to manipulate and apply serialized filter expressions coming from client. | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| PartitionIterable | PartitionIterable - effectively a lazy Iterable Sometimes, we have a need for iterating through a list of partitions, | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| PartitionKeySampler | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| PartitionListComposingSpec | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PartitionListComposingSpecProxy | PartitionSpecProxy implementation that composes a List of Partitions. | Class | org.apache.hadoop.hive.metastore.partition.spec | Apache Hive |
|
| PartitionPrune | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.rules | Apache Hive |
|
| PartitionPruner | The transformation step that does partition pruning. | Class | org.apache.hadoop.hive.ql.optimizer.ppr | Apache Hive |
|
| PartitionsByExprRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PartitionsByExprResult | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PartitionSpec | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PartitionSpecProxy | Polymorphic proxy class, equivalent to org. | Class | org.apache.hadoop.hive.metastore.partition.spec | Apache Hive |
|
| PartitionSpecWithSharedSD | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PartitionSpecWithSharedSDProxy | Subclass of PartitionSpecProxy that pulls out commonality of StorageDescriptor properties within a Partition-list into a common | Class | org.apache.hadoop.hive.metastore.partition.spec | Apache Hive |
|
| PartitionsStatsRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PartitionsStatsResult | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PartitionTableFunctionDescription | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| PartitionWithoutSD | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PasswdAuthenticationProvider | | Interface | org.apache.hive.service.auth | Apache Hive |
|
| PatternOrIdentifier | PatternOrIdentifier. | Class | org.apache.hive.service.cli | Apache Hive |
|
| PcrExprProcCtx | The processor context for partition condition remover. | Class | org.apache.hadoop.hive.ql.optimizer.pcr | Apache Hive |
|
| PcrExprProcFactory | Expression processor factory for partition condition removing. | Class | org.apache.hadoop.hive.ql.optimizer.pcr | Apache Hive |
|
| PcrOpProcFactory | PcrOpProcFactory contains processors that process expression tree of filter operators following table scan operators. | Class | org.apache.hadoop.hive.ql.optimizer.pcr | Apache Hive |
|
| PcrOpWalkerCtx | Context class for operator tree walker for partition condition remover. | Class | org.apache.hadoop.hive.ql.optimizer.pcr | Apache Hive |
|
| PerfLogger | Can be used to measure and log the time spent by a piece of code. | Class | org.apache.hadoop.hive.ql.log | Apache Hive |
|
| PhysicalContext | physical context used by physical resolvers. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| PhysicalOptimizer | A hierarchy physical optimizer, which contains a list of PhysicalPlanResolver. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| PhysicalPlanResolver | Physical plan optimization interface. | Interface | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| PidDailyRollingFileAppender | | Class | org.apache.hadoop.hive.ql.log | Apache Hive |
|
| PigDelegator | This is the backend of the pig web service. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| PlainSaslHelper | | Class | org.apache.hive.service.auth | Apache Hive |
|
| PlainSaslServer | Sun JDK only provides a PLAIN client and no server. | Class | org.apache.hive.service.auth | Apache Hive |
|
| PlanModifierForASTConv | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| PlanModifierForReturnPath | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| PlanModifierUtil | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| PlanUtils | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| PosModDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| PosModLongToLong | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| PostExecute | The post execute hook interface. | Interface | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| PostExecutePrinter | to standard output. | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| PreAddIndexEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreAddPartitionEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreAlterIndexEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreAlterPartitionEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreAlterTableEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreAuthorizationCallEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreCreateDatabaseEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreCreateTableEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PredicateLeaf | The primitive predicates that form a SearchArgument. | Interface | org.apache.hadoop.hive.ql.io.sarg | Apache Hive |
|
| PredicatePushDown | relational databases even though for Hive it is predicate pushup. | Class | org.apache.hadoop.hive.ql.ppd | Apache Hive |
|
| PredicateTransitivePropagate | | Class | org.apache.hadoop.hive.ql.ppd | Apache Hive |
|
| PreDropDatabaseEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreDropIndexEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreDropPartitionEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreDropTableEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreEventContext | Base class for all the events which are defined for metastore. | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreExecute | The pre execute hook interface. | Interface | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| PreExecutePrinter | | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| PreLoadPartitionDoneEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreOrderWalker | base class for operator graph walker this class takes list of starting ops and walks them one by one. | Class | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| PreReadDatabaseEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PreReadTableEvent | | Class | org.apache.hadoop.hive.metastore.events | Apache Hive |
|
| PrimitiveComparison | Wraps type-specific comparison operations over a constant value. | Interface | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| PrimitiveComparisonFilter | Operates over a single qualifier. | Class | org.apache.hadoop.hive.accumulo.predicate | Apache Hive |
|
| PrimitiveObjectInspector | PrimitiveObjectInspector. | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| PrimitiveObjectInspectorConverter | PrimitiveObjectInspectorConverter. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| PrimitiveObjectInspectorFactory | PrimitiveObjectInspectorFactory is the primary way to create new PrimitiveObjectInspector instances. | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| PrimitiveObjectInspectorUtils | ObjectInspectorFactory is the primary way to create new ObjectInspector SerDe classes should call the static functions in this library to create an | Class | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| PrimitiveTypeInfo | There are limited number of Primitive Types. | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| PrincipalDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| PrincipalPrivilegeSet | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PrincipalType | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PrintOpTreeProcessor | PrintOpTreeProcessor. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| Privilege | Privilege defines a privilege in Hive. | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| PrivilegeBag | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PrivilegeDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| PrivilegeGrantInfo | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| PrivilegeObjectDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| PrivilegeRegistry | PrivilegeRegistry is used to do privilege lookups. | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| PrivilegeScope | PrivilegeScope describes a hive defined privilege's scope (global/database/table/column). | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| PrivilegeType | | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| ProcessAnalyzeTable | ProcessAnalyzeTable sets up work for the several variants of analyze table (normal, no scan, partial scan. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ProjectionPusher | | Class | org.apache.hadoop.hive.ql.io.parquet | Apache Hive |
|
| PropValueUnion | | Class | org.apache.hadoop.hive.serde2.thrift.test | Apache Hive |
|
| ProtectMode | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| ProxyFileSystem | A FileSystem that can serve a given scheme/authority using some other file system. | Class | org.apache.hadoop.fs | Apache Hive |
|
| ProxyLocalFileSystem | A Proxy for LocalFileSystem Serves uri's corresponding to 'pfile:///' namespace with using | Class | org.apache.hadoop.fs | Apache Hive |
|
| ProxyUserAuthenticator | ProxyUserAuthenticator extends HadoopDefaultAuthenticator but honours a proxy config setting proxy. | Class | org.apache.hadoop.hive.ql.security | Apache Hive |
|
| PrunedPartitionList | The list of pruned partitions. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| PrunerExpressionOperatorFactory | Expression processor factory for pruning. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| PrunerOperatorFactory | Operator factory for pruning processing of operator graph We find all the filter operators that appear just beneath the table scan operators. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| PrunerUtils | General utility common functions for the Pruner to do optimization. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| PTFDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| PTFDeserializer | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| PTFExpressionDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| PTFInputDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| PTFInvocationSpec | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| PTFOperator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| PTFPartition | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| PTFQueryInputDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| PTFRollingPartition | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| PTFRowContainer | It extends RowContainer behavior in the following ways: You must continue to call first to signal the transition from writing to the | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| PTFTopNHash | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| PTFTranslator | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| PTFUtils | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| PushdownTuple | For use in IteratorSetting construction. | Class | org.apache.hadoop.hive.accumulo.predicate | Apache Hive |
|
| PutWritable | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| QB | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| QBExpr | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| QBJoinTree | Internal representation of the join tree. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| QBMetaData | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| QBParseInfo | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| QBSubQuery | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| QFileClient | | Class | org.apache.hive.beeline.util | Apache Hive |
|
| QTestGenTask | | Class | org.apache.hadoop.hive.ant | Apache Hive |
|
| Query | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| QueryFailedException | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| QueryPlan | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| QueryPlan | 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 | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| QueryPlanTreeTransformation | QueryPlanTreeTransformation contains static methods used to transform the query plan tree (operator tree) based on the correlation we have | Class | org.apache.hadoop.hive.ql.optimizer.correlation | Apache Hive |
|
| QueryProperties | A structure to contain features of a query that are determined during parsing and may be useful for categorizing a query type | Class | org.apache.hadoop.hive.ql | Apache Hive |
|
| QueueException | Unable to queue the jobSee Also:Serialized Form | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| QueueStatusBean | QueueStatusBean - The results of an exec call. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| RandomDimension | A random dimension is an abstract dimension. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| RangeBoundaryDef | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| RawStore | | Interface | org.apache.hadoop.hive.metastore | Apache Hive |
|
| RawStoreProxy | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| RCFile | RCFiles, short of Record Columnar File, are flat files consisting of binary key/value pairs, which shares much similarity with | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| RCFileBlockMergeInputFormat | | Class | org.apache.hadoop.hive.ql.io.rcfile.merge | Apache Hive |
|
| RCFileBlockMergeRecordReader | | Class | org.apache.hadoop.hive.ql.io.rcfile.merge | Apache Hive |
|
| RCFileCat | | Class | org.apache.hadoop.hive.cli | Apache Hive |
|
| RCFileInputFormat | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| RCFileKeyBufferWrapper | | Class | org.apache.hadoop.hive.ql.io.rcfile.merge | Apache Hive |
|
| RCFileMapReduceInputFormat | | Class | org.apache.hive.hcatalog.rcfile | Apache Hive |
|
| RCFileMapReduceOutputFormat | The RC file input format using new Hadoop mapreduce APIs. | Class | org.apache.hive.hcatalog.rcfile | Apache Hive |
|
| RCFileMapReduceRecordReader | | Class | org.apache.hive.hcatalog.rcfile | Apache Hive |
|
| RCFileMergeDesc | Descriptor for Fast file merge RC file operator. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| RCFileMergeOperator | Fast file merge operator for RC files. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| RCFileOutputFormat | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| RCFileRecordReader | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| RCFileStorageFormatDescriptor | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| RCFileValueBufferWrapper | | Class | org.apache.hadoop.hive.ql.io.rcfile.merge | Apache Hive |
|
| ReadEntity | This class encapsulates the information on the partition and tables that areSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| ReadEntity | | Class | org.apache.hive.hcatalog.data.transfer | Apache Hive |
|
| Reader | The interface for reading ORC files. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| ReaderContext | This read context is obtained by the master node and should be distributed to the slaves. | Interface | org.apache.hive.hcatalog.data.transfer | Apache Hive |
|
| ReaderImpl | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| ReaderWriter | | Class | org.apache.hive.hcatalog.data | Apache Hive |
|
| RecordIdentifier | Gives the Record identifier information for the current record. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| RecordProcessor | Process input from tez LogicalInput and write output It has different subclasses for map and reduce processing | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| RecordReader | | Interface | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| RecordReader | A row-by-row iterator for ORC files. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| RecordReaderFactory | Factory to create ORC tree readers. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| RecordReaderUtils | Stateless methods shared between RecordReaderImpl and EncodedReaderImpl. | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| RecordSource | | Interface | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| RecordUpdater | API for supporting updating records. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| RecordWriter | | Interface | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| RecordWriter | | Interface | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| Redactor | | Class | org.apache.hadoop.hive.ql.hooks | Apache Hive |
|
| Reducer | Simple reducer interface. | Interface | org.apache.hadoop.hive.contrib.mr | Apache Hive |
|
| ReduceRecordProcessor | Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| ReduceRecordSource | Process input from tez LogicalInput and write output - for a map plan Just pump the records through the query plan. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| ReducerTimeStatsPerJob | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ReduceSinkDeDuplication | If two reducer sink operators share the same partition/sort columns and order, they can be merged. | Class | org.apache.hadoop.hive.ql.optimizer.correlation | Apache Hive |
|
| ReduceSinkDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ReduceSinkMapJoinProc | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| ReduceSinkOperator | Reduce Sink Operator sends output to the reduce stage. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ReduceTezProcessor | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| ReduceTran | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| ReduceWork | ReduceWork represents all the information used to run a reduce task on the cluster. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ReflectionStructObjectInspector | ReflectionStructObjectInspector works on struct data that is stored as a native Java object. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ReflectionUtil | Same as Hadoop ReflectionUtils, but (1) does not leak classloaders (or shouldn't anyway, we rely on Guava cache, and could fix it otherwise); (2) does not have a hidden epic lock. | Class | org.apache.hive.common.util | Apache Hive |
|
| ReflectiveCommandHandler | A Command implementation that uses reflection to determine the method to dispatch the command. | Class | org.apache.hive.beeline | Apache Hive |
|
| RegexErrorHeuristic | 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. | Class | org.apache.hadoop.hive.ql.exec.errors | Apache Hive |
|
| RegexSerDe | RegexSerDe uses regular expression (regex) to serialize/deserialize. | Class | org.apache.hadoop.hive.contrib.serde2 | Apache Hive |
|
| RegexSerDe | RegexSerDe uses regular expression (regex) to deserialize data. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| Registry | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| ReloadFunctionDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ReloadProcessor | | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| RelOptHiveTable | | Class | org.apache.hadoop.hive.ql.optimizer.calcite | Apache Hive |
|
| RemoteDriver | Driver code for the Spark client library. | Class | org.apache.hive.spark.client | Apache Hive |
|
| RemoteHiveSparkClient | RemoteSparkClient is a wrapper of SparkClient, which wrap a spark job request and send to an remote SparkContext. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| RemoteSparkJobMonitor | RemoteSparkJobMonitor monitor a RSC remote job status in a loop until job finished/failed/killed. | Class | org.apache.hadoop.hive.ql.exec.spark.status | Apache Hive |
|
| RemoteSparkJobRef | | Class | org.apache.hadoop.hive.ql.exec.spark.status.impl | Apache Hive |
|
| RemoteSparkJobStatus | Used with remove spark client. | Class | org.apache.hadoop.hive.ql.exec.spark.status.impl | Apache Hive |
|
| RemoveDynamicPruningBySize | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| RenamePartitionDesc | Contains the information needed to rename a partition. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| Repeated | Converters for repeated fields need to know when the parent field starts and ends to correctly build lists from the repeated values. | Interface | org.apache.hadoop.hive.ql.io.parquet.convert | Apache Hive |
|
| ReplicationSpec | Statements executed to handle replication have some additional information relevant to the replication subsystem - this class | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| ReplicationTask | ReplicationTask captures the concept of what it'd take to replicate changes from one warehouse to another given a notification event that captures what changed. | Class | org.apache.hive.hcatalog.api.repl | Apache Hive |
|
| ReplicationUtils | | Class | org.apache.hive.hcatalog.api.repl | Apache Hive |
|
| RequestPartsSpec | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| RequiredPrivileges | Captures privilege sets, and can be used to compare required and available privileges to find missing privileges (if any). | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| ResetProcessor | | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| ResourceType | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ResourceUri | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ResultWritable | | Class | org.apache.hadoop.hive.hbase | Apache Hive |
|
| RetryingHMSHandler | | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| RetryingMetaStoreClient | RetryingMetaStoreClient. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| ReusableGetAdaptorDirectAccess | | Interface | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| RevokeDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| RevokePrivAuthUtils | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| ReworkMapredInputFormat | | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| RewriteCanApplyCtx | RewriteCanApplyCtx class stores the context for the RewriteCanApplyProcFactory to determine if any index can be used and if the input query | Class | org.apache.hadoop.hive.ql.optimizer.index | Apache Hive |
|
| RewriteCanApplyProcFactory | Factory of methods used by RewriteGBUsingIndex to determine if the rewrite optimization can be applied to the input query. | Class | org.apache.hadoop.hive.ql.optimizer.index | Apache Hive |
|
| RewriteGBUsingIndex | RewriteGBUsingIndex is implemented as one of the Rule-based Optimizations. | Class | org.apache.hadoop.hive.ql.optimizer.index | Apache Hive |
|
| RewriteParseContextGenerator | RewriteParseContextGenerator is a class that offers methods to generate operator tree for input queries. | Class | org.apache.hadoop.hive.ql.optimizer.index | Apache Hive |
|
| RewriteQueryUsingAggregateIndexCtx | RewriteQueryUsingAggregateIndexCtx class stores the context for the RewriteQueryUsingAggregateIndex | Class | org.apache.hadoop.hive.ql.optimizer.index | Apache Hive |
|
| RexNodeConverter | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| Role | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| RoleDDLDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| RolePrincipalGrant | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| RoundUtils | Utility class for generic round UDF. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| RoundWithNumDigitsDoubleToDouble | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| RowBasedSet | | Class | org.apache.hive.service.cli | Apache Hive |
|
| RowContainer | Simple persistent container for rows. | Class | org.apache.hadoop.hive.ql.exec.persistence | Apache Hive |
|
| RowResolver | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| RowSchema | RowSchema Implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| RowSet | | Interface | org.apache.hive.service.cli | Apache Hive |
|
| RowSetFactory | | Class | org.apache.hive.service.cli | Apache Hive |
|
| Rpc | Encapsulates the RPC functionality. | Class | org.apache.hive.spark.client.rpc | Apache Hive |
|
| RpcConfiguration | Definitions of configuration keys and default values for the RPC layer. | Class | org.apache.hive.spark.client.rpc | Apache Hive |
|
| RpcDispatcher | An implementation of ChannelInboundHandler that dispatches incoming messages to an instance method based on the method signature. | Class | org.apache.hive.spark.client.rpc | Apache Hive |
|
| RpcException | | Class | org.apache.hive.spark.client.rpc | Apache Hive |
|
| RpcServer | An RPC server. | Class | org.apache.hive.spark.client.rpc | Apache Hive |
|
| Rule | Rule interface for Operators Used in operator dispatching to dispatch process/visitor functions for operators. | Interface | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| RuleExactMatch | Implentation of the Rule interface for Nodes Used in Node dispatching to dispatch process/visitor functions for Nodes. | Class | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| RuleRegExp | Rule interface for Nodes Used in Node dispatching to dispatch process/visitor functions for Nodes. | Class | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| S3LogDeserializer | | Class | org.apache.hadoop.hive.contrib.serde2.s3 | Apache Hive |
|
| S3LogStruct | | Class | org.apache.hadoop.hive.contrib.serde2.s3 | Apache Hive |
|
| Sample | A sample defines a subset of data based on sampling on a given dimension. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| SamplePruner | The transformation step that does sample pruning. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SampleURLHook | First returns a url for a blank DB, then returns a URL for the original DB. | Class | org.apache.hadoop.hive.contrib.metastore.hooks | Apache Hive |
|
| SamplingOptimizer | | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| SaslQOP | Possible values of SASL quality-of-protection value. | Class | org.apache.hive.service.auth | Apache Hive |
|
| SchedulerShim | Shim for Fair scheduler HiveServer2 uses fair scheduler API to resolve the queue mapping for non-impersonation | Interface | org.apache.hadoop.hive.shims | Apache Hive |
|
| Schema | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| SchemaAwareCompressionInputStream | SchemaAwareCompressionInputStream adds the ability to inform the compression stream what column is being read. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| SchemaAwareCompressionOutputStream | SchemaAwareCompressionOutputStream adds the ability to inform the comression stream the current column being compressed. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| SchemaDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ScriptDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ScriptErrorHeuristic | Detects when a query has failed because a user's script that was specified in transform returns a non-zero error code. | Class | org.apache.hadoop.hive.ql.exec.errors | Apache Hive |
|
| ScriptOperator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| SearchArgument | Primary interface for SearchArgument, which are the subset of predicates | Interface | org.apache.hadoop.hive.ql.io.sarg | Apache Hive |
|
| SearchArgumentFactory | A factory for creating SearchArguments. | Class | org.apache.hadoop.hive.ql.io.sarg | Apache Hive |
|
| SecureCmdDoAs | SecureCmdDoAs - Helper class for setting parameters and env necessary for being able to run child jvm as intended user. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| SecureProxySupport | Helper class to run jobs using Kerberos security. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| SelectColumnIsFalse | This expression selects a row if the given boolean column is false. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| SelectColumnIsNotNull | This expression selects a row if the given column is null. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| SelectColumnIsNull | This expression selects a row if the given column is null. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| SelectColumnIsTrue | This expression selects a row if the given boolean column is true. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| SelectDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| SelectOperator | Select operator implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| SemanticAnalyzer | There are other specific semantic analyzers for some hive operations such as DDLSemanticAnalyzer for ddl operations. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| SemanticAnalyzerFactory | SemanticAnalyzerFactory. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| SemanticException | Exception from SemanticAnalyzer. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| SequenceFileInputFormatChecker | SequenceFileInputFormatChecker. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| SequenceFileStorageFormatDescriptor | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| SerDe | A union of HiveDeserializer and HiveSerializer interface. | Interface | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| serdeConstants | | Class | org.apache.hadoop.hive.serde | Apache Hive |
|
| SerDeException | Generic exception class for SerDes. | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| SerDeInfo | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| SerDeStats | | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| SerDeStatsStruct | | Interface | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| SerDeUtils | | Class | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| SerializationError | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| Serializer | HiveSerializer is used to serialize data to a Hadoop Writable object. | Interface | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| SerializeWrite | | Interface | org.apache.hadoop.hive.serde2.fast | Apache Hive |
|
| Server | The Templeton Web API server. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| ServerUtils | | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| Service | | Interface | org.apache.hive.service | Apache Hive |
|
| ServiceException | | Class | org.apache.hive.service | Apache Hive |
|
| ServiceOperations | | Class | org.apache.hive.service | Apache Hive |
|
| ServiceStateChangeListener | ServiceStateChangeListener. | Interface | org.apache.hive.service | Apache Hive |
|
| ServiceUtils | | Class | org.apache.hive.service | Apache Hive |
|
| SessionHandle | | Class | org.apache.hive.service.cli | Apache Hive |
|
| SessionHiveMetaStoreClient | | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| SessionManager | | Class | org.apache.hive.service.cli.session | Apache Hive |
|
| SessionPropertiesListener | It handles the changed properties in the change event. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| SessionState | SessionState encapsulates common data associated with a session. | Class | org.apache.hadoop.hive.ql.session | Apache Hive |
|
| SessionStateConfigUserAuthenticator | Authenticator to be used for testing and debugging. | Class | org.apache.hadoop.hive.ql.security | Apache Hive |
|
| SessionStateUserAuthenticator | Authenticator that returns the userName set in SessionState. | Class | org.apache.hadoop.hive.ql.security | Apache Hive |
|
| SetIntString | | Class | org.apache.hadoop.hive.serde2.thrift.test | Apache Hive |
|
| SetPartitionsStatsRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| SetProcessor | | Class | org.apache.hadoop.hive.ql.processors | Apache Hive |
|
| SetReducerParallelism | SetReducerParallelism determines how many reducers should be run for a given reduce sink. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SetSparkReducerParallelism | SetSparkReducerParallelism determines how many reducers should be run for a given reduce sink, clone from SetReducerParallelism. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SettableBinaryObjectInspector | | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableBooleanObjectInspector | A SettableBooleanObjectInspector can set a boolean value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableByteObjectInspector | A SettableByteObjectInspector can set a byte value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableConfigUpdater | Helper class that can be used by authorization implementations to set a default list of 'safe' HiveConf parameters that can be edited by user. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin | Apache Hive |
|
| SettableDateObjectInspector | A SettableDecimalObjectInspector can set a Date value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableDoubleObjectInspector | A SettableDoubleObjectInspector can set a double value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableFloatObjectInspector | A SettableFloatObjectInspector can set a float value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableHiveCharObjectInspector | | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableHiveDecimalObjectInspector | A SettableDecimalObjectInspector can set a HiveDecimal value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableHiveIntervalDayTimeObjectInspector | A SettableHiveIntervalDayTimeObjectInspector can set a IntervalDayTime value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableHiveIntervalYearMonthObjectInspector | A SettableHiveIntervalYearMonthObjectInspector can set a IntervalYearMonth value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableHiveVarcharObjectInspector | | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableIntObjectInspector | A SettableIntObjectInspector can set an int value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableListObjectInspector | SettableListObjectInspector. | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| SettableLongObjectInspector | A SettableLongObjectInspector can set a long value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableMapObjectInspector | SettableMapObjectInspector. | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| SettableShortObjectInspector | A SettableShortObjectInspector can set a short value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableStringObjectInspector | A SettableStringObjectInspector can set a string value to an object. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableStructObjectInspector | SettableStructObjectInspector. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| SettableTimestampObjectInspector | | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| SettableUDF | THIS INTERFACE IS UNSTABLE AND SHOULD NOT BE USED BY 3RD PARTY UDFS. | Interface | org.apache.hadoop.hive.ql.udf | Apache Hive |
|
| SettableUnionObjectInspector | SettableUnionObjectInspector. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| ShapeDetails | | Class | org.apache.hadoop.hive.ql.plan.ptf | Apache Hive |
|
| ShellCmdExecutor | | Class | org.apache.hadoop.hive.common.cli | Apache Hive |
|
| ShimLoader | | Class | org.apache.hadoop.hive.shims | Apache Hive |
|
| ShortObjectInspector | A ShortObjectInspector inspects an Object representing a Short. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| ShortWritable | | Class | org.apache.hadoop.hive.serde2.io | Apache Hive |
|
| ShowColumnsDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowCompactionsDesc | Descriptor for showing compactions. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowCompactRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ShowCompactResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ShowCompactResponseElement | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ShowConfDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowCreateTableDesc | ShowCreateTableDesc. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowDatabasesDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowFunctionsDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowGrantDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowIndexesDesc | Returns table index information per SQL syntax. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowLocksDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowLocksRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ShowLocksResponse | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ShowLocksResponseElement | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| ShowPartitionsDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowTablesDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowTableStatusDesc | ShowTableStatusDesc. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowTblPropertiesDesc | ShowTblPropertiesDesc. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShowTxnsDesc | Descriptor for showing transactions. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| ShuffleReadMetrics | Metrics pertaining to reading shuffle data. | Class | org.apache.hive.spark.client.metrics | Apache Hive |
|
| ShuffleTran | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| ShuffleWriteMetrics | Metrics pertaining to writing shuffle data. | Class | org.apache.hive.spark.client.metrics | Apache Hive |
|
| ShutdownHookManager | The ShutdownHookManager enables running shutdownHook in a deterministic order, higher priority first. | Class | org.apache.hive.common.util | Apache Hive |
|
| SignedInt128 | This code was based on code from Microsoft's PolyBase. | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| SimpleCharStream | An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing). | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| SimpleExceptionMapper | Map our exceptions to the Jersey response. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| SimpleFetchAggregation | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SimpleFetchOptimizer | Tries to convert simple fetch query to single fetch task, which fetches rows directly from location of table/partition. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SimpleGenericUDAFParameterInfo | A simple implementation of GenericUDAFParameterInfo. | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| SimpleMapEqualComparer | | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| SimpleNode | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| SimpleWebException | Simple exception that will return a json error payload if thrown from a JAX web server. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| SingleInputFormat | An empty InputFormat. | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| SizeBasedBigTableSelectorForAutoSMJ | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SkewedColumnPositionPair | This class record 2 types of positions for a skewed column: 1. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| SkewedInfo | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| SkewJoinHandler | 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 | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| SkewJoinOptimizer | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SkewJoinProcFactory | Node processor factory for skew join resolver. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| SkewJoinResolver | An implementation of PhysicalPlanResolver. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| SkippableTProtocol | | Interface | org.apache.hadoop.hive.serde2.thrift | Apache Hive |
|
| SMBJoinDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| SMBMapJoinOperator | Sorted Merge Map Join Operator. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| SortAndDigestPrintStream | | Class | org.apache.hadoop.hive.common.io | Apache Hive |
|
| SortBucketJoinProcCtx | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SortByShuffler | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SortedDynPartitionOptimizer | When dynamic partitioning (with or without bucketing and sorting) is enabled, this optimization sorts the records on partition, bucket and sort columns respectively before inserting records | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SortedMergeBucketMapJoinOptimizer | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SortedMergeBucketMapjoinProc | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SortedMergeJoinProc | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SortMergeJoinResolver | | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| SortMergeJoinTaskDispatcher | Iterator over each task. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| SortPrintStream | | Class | org.apache.hadoop.hive.common.io | Apache Hive |
|
| SparkBucketMapJoinContext | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| SparkClient | Defines the API for the Spark remote client. | Interface | org.apache.hive.spark.client | Apache Hive |
|
| SparkClientFactory | Factory for SparkClient instances. | Class | org.apache.hive.spark.client | Apache Hive |
|
| SparkClientUtilities | | Class | org.apache.hive.spark.client | Apache Hive |
|
| SparkCompiler | SparkCompiler translates the operator plan into SparkTasks. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| SparkCounter | | Class | org.apache.hive.spark.counter | Apache Hive |
|
| SparkCounterGroup | We use group to fold all the same kind of counters. | Class | org.apache.hive.spark.counter | Apache Hive |
|
| SparkCounters | SparkCounters is used to collect Hive operator metric through Spark accumulator. | Class | org.apache.hive.spark.counter | Apache Hive |
|
| SparkCrossProductCheck | Check each MapJoin and ShuffleJoin Operator to see if they are performing a cross product. | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| SparkEdgeProperty | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| SparkFileSinkProcessor | FileSinkProcessor handles addition of merge, move and stats tasks for filesinks. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| SparkHashTableSinkDesc | Map Join operator Descriptor implementation. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| SparkHashTableSinkOperator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| SparkJobRef | | Interface | org.apache.hadoop.hive.ql.exec.spark.status | Apache Hive |
|
| SparkJobState | | Class | org.apache.hadoop.hive.ql.exec.spark.status | Apache Hive |
|
| SparkJobStatus | SparkJobStatus identify what Hive want to know about the status of a Spark job. | Interface | org.apache.hadoop.hive.ql.exec.spark.status | Apache Hive |
|
| SparkJoinHintOptimizer | This processes joins in which user specified a hint to identify the small-table. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkJoinOptimizer | Converts a join to a more optimized join for the Spark path. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkMapJoinOptimizer | SparkMapJoinOptimizer cloned from ConvertJoinMapJoin is an optimization that replaces a common join (aka shuffle join) with a map join (aka broadcast or fragment replicate | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkMapJoinProcessor | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| SparkMapJoinResolver | | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| SparkMapRecordHandler | Clone from ExecMapper. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkMergeFileRecordHandler | Copied from MergeFileMapper. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkPlan | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkPlanGenerator | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkProcessAnalyzeTable | ProcessAnalyzeTable sets up work for the several variants of analyze table (normal, no scan, partial scan. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| SparkRecordHandler | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkReduceRecordHandler | Clone from ExecReducer, it is the bridge between the spark framework and the Hive operator pipeline at execution time. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkReduceSinkMapJoinProc | | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkReporter | UnsupportedOperationException for other unrelated methods, so if any Hive feature depends on these unimplemented methods, we could go back here quickly and enable it. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkSession | | Interface | org.apache.hadoop.hive.ql.exec.spark.session | Apache Hive |
|
| SparkSessionImpl | | Class | org.apache.hadoop.hive.ql.exec.spark.session | Apache Hive |
|
| SparkSessionManager | Defines interface for managing multiple SparkSessions in Hive when multiple users are executing queries simultaneously on Spark execution engine. | Interface | org.apache.hadoop.hive.ql.exec.spark.session | Apache Hive |
|
| SparkSessionManagerImpl | Simple implementation of SparkSessionManager - returns SparkSession when requested through getSession and keeps track of | Class | org.apache.hadoop.hive.ql.exec.spark.session | Apache Hive |
|
| SparkShuffler | | Interface | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkSkewJoinProcFactory | Spark-version of SkewJoinProcFactory. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkSkewJoinResolver | Spark version of SkewJoinResolver. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkSMBJoinHintOptimizer | Converts from a bucket-mapjoin created from hints to SMB mapjoin. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkSMBMapJoinInfo | Data structure to keep track of SMBMapJoin operators during query compilation for Spark. | Class | org.apache.hadoop.hive.ql.parse.spark | Apache Hive |
|
| SparkSortMergeJoinFactory | Operator factory for Spark SMBJoin processing. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkSortMergeJoinOptimizer | Converts a common join operator to an SMB join if eligible. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SparkStageProgress | | Class | org.apache.hadoop.hive.ql.exec.spark.status | Apache Hive |
|
| SparkStatistic | | Class | org.apache.hadoop.hive.ql.exec.spark.Statistic | Apache Hive |
|
| SparkStatisticGroup | | Class | org.apache.hadoop.hive.ql.exec.spark.Statistic | Apache Hive |
|
| SparkStatistics | | Class | org.apache.hadoop.hive.ql.exec.spark.Statistic | Apache Hive |
|
| SparkStatisticsBuilder | | Class | org.apache.hadoop.hive.ql.exec.spark.Statistic | Apache Hive |
|
| SparkTask | | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkTran | | Interface | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkUtilities | Contains utilities methods used as part of Spark tasks. | Class | org.apache.hadoop.hive.ql.exec.spark | Apache Hive |
|
| SparkWork | This class encapsulates all the work objects that can be executed in a single Spark job. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| SpecialCases | This class is a place to put all the code associated with Special cases. | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| SplitGrouper | SplitGrouper is used to combine splits based on head room and locality. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| SplitSample | This class stores all the information specified in the TABLESAMPLE(. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| SplitSparkWorkResolver | Do a BFS on the sparkWork graph, and look for any work that has more than one child. | Class | org.apache.hadoop.hive.ql.optimizer.spark | Apache Hive |
|
| SQLAuthorizationUtils | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| SqlFunctionConverter | | Class | org.apache.hadoop.hive.ql.optimizer.calcite.translator | Apache Hive |
|
| SqlMathUtil | This code was based on code from Microsoft's PolyBase. | Class | org.apache.hadoop.hive.common.type | Apache Hive |
|
| SQLOperation | | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| SQLPrivilegeType | enum SQLPrivilegeTypeEnum Constant Summary | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| SQLPrivTypeGrant | enum SQLPrivTypeGrantEnum Constant Summary | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| SQLStdConfOnlyAuthorizerFactory | Authorization class that can be used from hive cli, so that configuration in cli mode is set appropriately for SQL standards authorization. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| SQLStdHiveAccessController | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| SQLStdHiveAccessControllerWrapper | Wrapper for SQLStdHiveAccessController that does validation of arguments and then calls the real object. | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| SQLStdHiveAuthorizationValidator | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| SQLStdHiveAuthorizerFactory | | Class | org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd | Apache Hive |
|
| SqoopDelegator | This is the backend of the Sqoop web service. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| Stage | | Class | org.apache.hadoop.hive.common.jsonexplain.tez | Apache Hive |
|
| Stage | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| StageIDsRearranger | | Class | org.apache.hadoop.hive.ql.optimizer.physical | Apache Hive |
|
| StageType | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| StagingDirectoryProvider | | Interface | org.apache.hive.hcatalog.api.repl | Apache Hive |
|
| StandardConstantListObjectInspector | A StandardListObjectInspector which also implements the ConstantObjectInspector interface. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| StandardConstantMapObjectInspector | A StandardMapObjectInspector which also implements the ConstantObjectInspector interface. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| StandardListObjectInspector | DefaultListObjectInspector works on list data that is stored as a Java List or Java Array object. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| StandardMapObjectInspector | StandardMapObjectInspector works on map data that is stored as a Java Map object. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| StandardParquetHiveMapInspector | The StandardParquetHiveMapInspector will inspect an ArrayWritable, considering it as a Hive map. | Class | org.apache.hadoop.hive.ql.io.parquet.serde | Apache Hive |
|
| StandardStructObjectInspector | ListStructObjectInspector works on struct data that is stored as a Java List or Java Array object. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| StandardUnionObjectInspector | StandardUnionObjectInspector works on union data that is stored as It holds the list of the object inspectors corresponding to each type of the | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| Stat | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| StateProvider | If external system wants to communicate any state to slaves, they can do so via this interface. | Interface | org.apache.hive.hcatalog.data.transfer.state | Apache Hive |
|
| Statistics | Statistics. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| StatObjectConverter | This class contains conversion logic that creates Thrift stat objects from JDO stat objects and plain arrays from DirectSQL. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| StatsAggregator | An interface for any possible implementation for gathering statistics. | Interface | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| StatsFactory | A factory of stats publisher and aggregator implementations of the StatsPublisher and StatsAggregator interfaces. | Class | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| StatsNoJobTask | StatsNoJobTask is used in cases where stats collection is the only task for the given query (no parent MR or Tez job). | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| StatsNoJobWork | Client-side stats aggregator task. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| StatsOptimizer | There is a set of queries which can be answered entirely from statistics stored in metastore. | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| StatsProvidingRecordReader | If a file format internally gathers statistics (like ORC) then it can expose the statistics through this interface. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| StatsProvidingRecordWriter | If a file format internally gathers statistics (like ORC) while writing then it can expose the statistics through this record writer interface. | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| StatsPublisher | An interface for any possible implementation for publishing statics. | Interface | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| StatsRulesProcFactory | | Class | org.apache.hadoop.hive.ql.optimizer.stats.annotation | Apache Hive |
|
| StatsSetupConst | A class that defines the constant strings used by the statistics implementation. | Class | org.apache.hadoop.hive.common | Apache Hive |
|
| StatsTask | StatsTask implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| StatsUtils | | Class | org.apache.hadoop.hive.ql.stats | Apache Hive |
|
| StatsWork | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| StatusDelegator | Fetch the status of a given job id in the queue. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| StorageBasedAuthorizationProvider | StorageBasedAuthorizationProvider is an implementation of HiveMetastoreAuthorizationProvider that tries to look at the hdfs | Class | org.apache.hadoop.hive.ql.security.authorization | Apache Hive |
|
| StorageDescriptor | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| StorageFormat | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| StorageFormatDescriptor | Subclasses represent a storage format for the CREATE TABLE . | Interface | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| StorageFormatFactory | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| StorerInfo | Information about the storer to use for writing the data. | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| StreamingConnection | Represents a connection to a HiveEndPoint. | Interface | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| StreamingDelegator | Submit a streaming job to the MapReduce queue. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| StreamingException | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| StreamingIOFailure | | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| StreamPrinter | | Class | org.apache.hive.common.util | Apache Hive |
|
| StrictJsonWriter | Streaming Writer handles utf8 encoded Json (Strict syntax). | Class | org.apache.hive.hcatalog.streaming | Apache Hive |
|
| StringColumnInList | Evaluate an IN boolean expression (not a filter) on a batch for a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringColumnStatistics | Statistics for string columns. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| StringColumnStatsData | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| StringCompare | Set of comparison operations over a string constant. | Class | org.apache.hadoop.hive.accumulo.predicate.compare | Apache Hive |
|
| StringExpr | String expression evaluation helper functions. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringGroupColConcatCharScalar | Vectorized instruction to concatenate a string column to a scalar and put the result in an output column. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringGroupColConcatStringScalar | Vectorized instruction to concatenate a string column to a scalar and put the result in an output column. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringGroupColConcatVarCharScalar | Vectorized instruction to concatenate a string column to a scalar and put the result in an output column. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringGroupColEqualCharScalar | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColEqualStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColEqualStringGroupScalarBase | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColEqualStringScalar | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColEqualVarCharScalar | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterCharScalar | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterEqualCharScalar | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterEqualStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterEqualStringGroupScalarBase | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterEqualStringScalar | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterEqualVarCharScalar | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterStringGroupScalarBase | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterStringScalar | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColGreaterVarCharScalar | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessCharScalar | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessEqualCharScalar | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessEqualStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessEqualStringGroupScalarBase | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessEqualStringScalar | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessEqualVarCharScalar | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessStringGroupScalarBase | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessStringScalar | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColLessVarCharScalar | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColNotEqualCharScalar | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColNotEqualStringGroupColumn | Filter the rows in a batch by comparing one string column to another. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColNotEqualStringGroupScalarBase | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColNotEqualStringScalar | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupColNotEqualVarCharScalar | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupConcatColCol | Vectorized instruction to concatenate two string columns and put the output in a third column. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringGroupScalarEqualStringGroupColumnBase | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupScalarGreaterEqualStringGroupColumnBase | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupScalarGreaterStringGroupColumnBase | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupScalarLessEqualStringGroupColumnBase | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupScalarLessStringGroupColumnBase | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringGroupScalarNotEqualStringGroupColumnBase | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringHex | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringInitCap | Returns str, with the first letter of each word in uppercase, all other letters in lowercase. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringLength | Calculate the length of the strings in the input column vector, and store it in the output column vector. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringLower | Expression to convert a string to lower case. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringLTrim | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringNumDistinctValueEstimator | | Class | org.apache.hadoop.hive.ql.udf.generic | Apache Hive |
|
| StringObjectInspector | A StringObjectInspector inspects an Object representing a String. | Interface | org.apache.hadoop.hive.serde2.objectinspector.primitive | Apache Hive |
|
| StringRTrim | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringScalarConcatStringGroupCol | Vectorized instruction to concatenate a scalar to a string column and put the result in an output column. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringScalarEqualStringGroupColumn | This is a generated class to evaluate a == comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringScalarGreaterEqualStringGroupColumn | This is a generated class to evaluate a >= comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringScalarGreaterStringGroupColumn | This is a generated class to evaluate a > comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringScalarLessEqualStringGroupColumn | This is a generated class to evaluate a See Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringScalarLessStringGroupColumn | This is a generated class to evaluate a < comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringScalarNotEqualStringGroupColumn | This is a generated class to evaluate a != comparison on a vector of strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions.gen | Apache Hive |
|
| StringSubstrColStart | This class provides the implementation of vectorized substring, with a single start index parameter. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringSubstrColStartLen | This class provides the implementation of vectorized substring, with a start index and length parameters. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringTrim | | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringUnaryUDF | Expression for vectorized evaluation of unary UDFs on strings. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringUnaryUDFDirect | This is a superclass for unary string functions that operate directly on the input and set the output. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StringUpper | Expression to convert a string to lower case. | Class | org.apache.hadoop.hive.ql.exec.vector.expressions | Apache Hive |
|
| StripeInformation | Information about the stripes in an ORC file that is provided by the Reader. | Interface | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| StripeStatistics | | Class | org.apache.hadoop.hive.ql.io.orc | Apache Hive |
|
| StructField | Classes implementing this interface are considered to represent a field of a struct for this serde package. | Interface | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| StructHBaseValueFactory | | Class | org.apache.hadoop.hive.hbase.struct | Apache Hive |
|
| StructObject | | Interface | org.apache.hadoop.hive.serde2 | Apache Hive |
|
| StructObjectInspector | StructObjectInspector. | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| StructTypeInfo | StructTypeInfo represents the TypeInfo of a struct. | Class | org.apache.hadoop.hive.serde2.typeinfo | Apache Hive |
|
| SubQueryDiagnostic | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| SubQueryUtils | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| SubStructObjectInspector | 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 | Class | org.apache.hadoop.hive.serde2.objectinspector | Apache Hive |
|
| SunSignalHandler | | Class | org.apache.hive.beeline | Apache Hive |
|
| SwitchDatabaseDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| SymbolicInputFormat | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| SymlinkTextInputFormat | Symlink file is a text file which contains a list of filename / dirname. | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| SyntheticJoinPredicate | | Class | org.apache.hadoop.hive.ql.ppd | Apache Hive |
|
| SystemVariables | | Class | org.apache.hadoop.hive.conf | Apache Hive |
|
| Table | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| Table | A Hive Table: is a fundamental unit of data in Hive that shares a common schema/DDL. | Class | org.apache.hadoop.hive.ql.metadata | Apache Hive |
|
| TableAccessAnalyzer | TableAccessAnalyzer walks the operator graph from joins and group bys to the table scan operator backing it. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| TableAccessCtx | This class implements the context information that is used for typechecking phase in query compilation. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| TableAccessInfo | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| TableBasedIndexHandler | Index handler for indexes that use tables to store indexes. | Class | org.apache.hadoop.hive.ql.index | Apache Hive |
|
| TableDesc | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| TableDesc | A description of the table to create. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| TableFunctionEvaluator | Based on Hive GenericUDAFEvaluator. | Class | org.apache.hadoop.hive.ql.udf.ptf | Apache Hive |
|
| TableFunctionResolver | Based on Hive GenericUDAFResolver. | Class | org.apache.hadoop.hive.ql.udf.ptf | Apache Hive |
|
| TableLikeDesc | A description of the table to create that's like another table. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| TablePropertyDesc | A description of a table property. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| TableSample | This class stores all the information specified in the TABLESAMPLE clause. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| TableScanDesc | Table Scan Descriptor Currently, data is only read from a base source as part of map-reduce framework. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| TableScanOperator | Table Scan Operator If the data is coming from the map-reduce framework, just forward it. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TableSchema | | Class | org.apache.hive.service.cli | Apache Hive |
|
| TableSizeBasedBigTableSelectorForAutoSMJ | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| TableStatsRequest | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| TableStatsResult | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |
|
| TableType | Typesafe enum for types of tables described by the metastore. | Class | org.apache.hadoop.hive.metastore | Apache Hive |
|
| TableTypeMapping | | Interface | org.apache.hive.service.cli.operation | Apache Hive |
|
| TableTypeMappingFactory | | Class | org.apache.hive.service.cli.operation | Apache Hive |
|
| TArrayTypeEntry | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| Task | Task implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| Task | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| TaskCommitContextRegistry | Singleton Registry to track the commit of TaskAttempts. | Class | org.apache.hive.hcatalog.mapreduce | Apache Hive |
|
| TaskCompiler | TaskCompiler is a the base class for classes that compile operator pipelines into tasks. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| TaskCompilerFactory | | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| TaskExecutionException | Exception thrown by any task processor to signal a problem with taskSee Also:Serialized Form | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TaskFactory | TaskFactory implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TaskGraphWalker | base class for operator graph walker this class takes list of starting ops and walks them one by one. | Class | org.apache.hadoop.hive.ql.lib | Apache Hive |
|
| TaskHandle | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TaskLogProcessor | TaskLogProcessor reads the logs from failed task attempts and tries to figure out what the cause of the error was using various heuristics. | Class | org.apache.hadoop.hive.ql.exec.errors | Apache Hive |
|
| TaskResult | TaskResult implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TaskRunner | TaskRunner implementation. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TaskType | | Class | org.apache.hadoop.hive.ql.plan.api | Apache Hive |
|
| TBinaryColumn | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TBinarySortableProtocol | An implementation of the Thrift Protocol for binary sortable records. | Class | org.apache.hadoop.hive.serde2.thrift | Apache Hive |
|
| TBoolColumn | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TBoolValue | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TByteColumn | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TByteValue | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCancelDelegationTokenReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCancelDelegationTokenResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCancelOperationReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCancelOperationResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCLIService | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCLIServiceConstants | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCloseOperationReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCloseOperationResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCloseSessionReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCloseSessionResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TColumn | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TColumnDesc | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TColumnValue | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TCTLSeparatedProtocol | An implementation of the Thrift Protocol for ctl separated records. | Class | org.apache.hadoop.hive.serde2.thrift | Apache Hive |
|
| TDoubleColumn | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TDoubleValue | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TempletonControllerJob | A Map Reduce job that will start another job. | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| TempletonDelegator | The helper class for all the Templeton delegator classes. | Class | org.apache.hive.hcatalog.templeton | Apache Hive |
|
| TempletonStorage | An interface to handle different Templeton storage methods, including ZooKeeper and HDFS. | Interface | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| TempletonUtils | General utility methods. | Class | org.apache.hive.hcatalog.templeton.tool | Apache Hive |
|
| TemporaryHashSinkOperator | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TerminalOperator | Terminal Operator Base Class. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TExecuteStatementReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TExecuteStatementResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TextFileStorageFormatDescriptor | | Class | org.apache.hadoop.hive.ql.io | Apache Hive |
|
| TextRecordReader | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TextRecordWriter | | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TezBucketJoinProcCtx | | Class | org.apache.hadoop.hive.ql.optimizer | Apache Hive |
|
| TezCompiler | TezCompiler translates the operator plan into TezTasks. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| TezContext | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| TezDummyStoreOperator | A dummy store operator same as the dummy store operator but for tez. | Class | org.apache.hadoop.hive.ql.exec | Apache Hive |
|
| TezEdgeProperty | | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| TezJobExecHelper | TezJobExecHelper is a utility to safely call Tez functionality from common code paths. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| TezJobMonitor | TezJobMonitor keeps track of a tez job while it's being executed. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| TezJsonParser | | Class | org.apache.hadoop.hive.common.jsonexplain.tez | Apache Hive |
|
| TezMergedLogicalInput | TezMergedLogicalInput is an adapter to make union input look like a single input in tez. | Class | org.apache.hadoop.hive.ql.exec.tez.tools | Apache Hive |
|
| TezProcessor | Hive processor for Tez that forms the vertices in Tez and processes the data. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| TezSessionPoolManager | This class is for managing multiple tez sessions particularly when HiveServer2 is being used to submit queries. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| TezSessionState | | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| TezTask | TezTask handles the execution of TezWork. | Class | org.apache.hadoop.hive.ql.exec.tez | Apache Hive |
|
| TezWalker | Walks the operator tree in DFS fashion. | Class | org.apache.hadoop.hive.ql.parse | Apache Hive |
|
| TezWork | TezWork. | Class | org.apache.hadoop.hive.ql.plan | Apache Hive |
|
| TFetchOrientation | enum TFetchOrientationEnum Constant Summary | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TFetchResultsReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TFetchResultsResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TFilterTransport | Transport that simply wraps another transport. | Class | org.apache.hadoop.hive.thrift | Apache Hive |
|
| TGetCatalogsReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetCatalogsResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetColumnsReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetColumnsResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetDelegationTokenReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetDelegationTokenResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetFunctionsReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetFunctionsResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetInfoReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetInfoResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetInfoType | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetInfoValue | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetOperationStatusReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetOperationStatusResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetResultSetMetadataReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetResultSetMetadataResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetSchemasReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetSchemasResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetTablesReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetTablesResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetTableTypesReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetTableTypesResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetTypeInfoReq | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| TGetTypeInfoResp | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| THandleIdentifier | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| ThreadFactoryWithGarbageCleanup | A ThreadFactory for constructing new HiveServer2 threads that lets you plug in custom cleanup code to be called before this thread is GC-ed. | Class | org.apache.hive.service.server | Apache Hive |
|
| ThreadWithGarbageCleanup | A HiveServer2 thread used to construct new server threads. | Class | org.apache.hive.service.server | Apache Hive |
|
| thrift_grammar | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| thrift_grammarConstants | Token literal values and constants. | Interface | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| thrift_grammarTokenManager | | Class | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| thrift_grammarTreeConstants | | Interface | org.apache.hadoop.hive.serde2.dynamic_type | Apache Hive |
|
| ThriftBinaryCLIService | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| ThriftByteStreamTypedSerDe | ThriftByteStreamTypedSerDe. | Class | org.apache.hadoop.hive.serde2.thrift | Apache Hive |
|
| ThriftCLIService | | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| ThriftCLIServiceClient | ThriftCLIServiceClient. | Class | org.apache.hive.service.cli.thrift | Apache Hive |
|
| ThriftDeserializer | | Class | org.apache.hadoop.hive.serde2.thrift | Apache Hive |
|
| ThriftHive | | Class | org.apache.hadoop.hive.service | Apache Hive |
|
| ThriftHiveMetastore | | Class | org.apache.hadoop.hive.metastore.api | Apache Hive |