|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql | |
---|---|
FetchTask
FetchTask implementation. |
|
Task
Task implementation. |
|
TaskResult
TaskResult implementation. |
|
TaskRunner
TaskRunner implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.exec | |
---|---|
AbstractMapJoinOperator
|
|
ArchiveUtils.PartSpecInfo
PartSpecInfo keeps fields and values extracted from partial partition info which is prefix of the full info. |
|
BucketMatcher
|
|
ColumnInfo
Implementation for ColumnInfo which contains the internal name for the column (the one that is used by the operator to access the column) and the type (identified by a java class). |
|
CommonJoinOperator
Join operator implementation. |
|
DefaultUDAFEvaluatorResolver
The default UDAF Method resolver. |
|
ExecDriver
ExecDriver. |
|
ExecMapperContext
|
|
ExprNodeEvaluator
ExprNodeEvaluator. |
|
FetchOperator
FetchTask implementation. |
|
FileSinkOperator.FSPaths
|
|
FileSinkOperator.RecordWriter
RecordWriter. |
|
FileSinkOperator.TableIdEnum
TableIdEnum. |
|
FilterOperator.Counter
Counter. |
|
FunctionInfo
FunctionInfo. |
|
HadoopJobExecHelper
|
|
HadoopJobExecHook
|
|
HashTableSinkOperator.HashTableSinkObjectCtx
|
|
JobCloseFeedBack
After this job closed, some data (feedbacks) can be passed to descendant jobs. |
|
JobCloseFeedBack.FeedBackType
|
|
JoinOperator.SkewkeyTableCounter
SkewkeyTableCounter. |
|
KeyWrapper
|
|
ListSinkOperator
For fetch task with operator tree, row read from FetchOperator is processed via operator tree and finally arrives to this operator. |
|
MapJoinOperator
Map side Join operator implementation. |
|
MapOperator.Counter
Counter. |
|
Operator
Base operator implementation. |
|
Operator.OperatorFunc
OperatorFunc. |
|
Operator.ProgressCounter
TODO This is a hack for hadoop 0.17 which only supports enum counters. |
|
Operator.State
State. |
|
OperatorFactory.OpTuple
OpTuple. |
|
RecordReader
RecordReader. |
|
RecordWriter
RecordWriter. |
|
RowSchema
RowSchema Implementation. |
|
ScriptOperator.Counter
Counter. |
|
Task
Task implementation. |
|
Task.FeedType
|
|
TaskFactory.taskTuple
taskTuple. |
|
TaskHandle
TaskHandle. |
|
TaskResult
TaskResult implementation. |
|
TerminalOperator
Terminal Operator Base Class. |
|
UDAF
Base class for all User-defined Aggregation Function (UDAF) classes. |
|
UDAFEvaluator
Interface that encapsulates the evaluation logic of a UDAF. |
|
UDAFEvaluatorResolver
The UDF Method resolver interface. |
|
UDF
A User-defined function (UDF) for the use with Hive. |
|
UDFArgumentException
exception class, thrown when udf argument have something wrong. |
|
UDFMethodResolver
The UDF Method resolver interface. |
|
Utilities.ReduceField
ReduceField. |
|
Utilities.SQLCommand
|
|
Utilities.StreamStatus
StreamStatus. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.history | |
---|---|
Task
Task implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.hooks | |
---|---|
Task
Task implementation. |
|
TaskRunner
TaskRunner implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.index | |
---|---|
Task
Task implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.index.bitmap | |
---|---|
Task
Task implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.index.compact | |
---|---|
Task
Task implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.io | |
---|---|
FileSinkOperator.RecordWriter
RecordWriter. |
|
Operator
Base operator implementation. |
|
TableScanOperator
Table Scan Operator If the data is coming from the map-reduce framework, just forward it. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.io.avro | |
---|---|
FileSinkOperator.RecordWriter
RecordWriter. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.io.rcfile.merge | |
---|---|
HadoopJobExecHelper
|
|
HadoopJobExecHook
|
|
Task
Task implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.io.udf | |
---|---|
FileSinkOperator.RecordWriter
RecordWriter. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.metadata | |
---|---|
Task
Task implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer | |
---|---|
AbstractMapJoinOperator
|
|
CommonJoinOperator
Join operator implementation. |
|
DependencyCollectionTask
DependencyCollectionTask. |
|
FileSinkOperator
File Sink operator implementation. |
|
FilterOperator
Filter operator implementation. |
|
GroupByOperator
GroupBy operator implementation. |
|
JoinOperator
Join operator implementation. |
|
MapJoinOperator
Map side Join operator implementation. |
|
Operator
Base operator implementation. |
|
ReduceSinkOperator
Reduce Sink Operator sends output to the reduce stage. |
|
SelectOperator
Select operator implementation. |
|
TableScanOperator
Table Scan Operator If the data is coming from the map-reduce framework, just forward it. |
|
Task
Task implementation. |
|
UDFArgumentException
exception class, thrown when udf argument have something wrong. |
|
UnionOperator
Union Operator Just forwards. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer.index | |
---|---|
Operator
Base operator implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer.lineage | |
---|---|
ColumnInfo
Implementation for ColumnInfo which contains the internal name for the column (the one that is used by the operator to access the column) and the type (identified by a java class). |
|
Operator
Base operator implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer.listbucketingpruner | |
---|---|
FilterOperator
Filter operator implementation. |
|
TableScanOperator
Table Scan Operator If the data is coming from the map-reduce framework, just forward it. |
|
UDFArgumentException
exception class, thrown when udf argument have something wrong. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer.pcr | |
---|---|
FilterOperator
Filter operator implementation. |
|
Operator
Base operator implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer.physical | |
---|---|
JoinOperator
Join operator implementation. |
|
Operator
Base operator implementation. |
|
Task
Task implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer.physical.index | |
---|---|
Task
Task implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer.ppr | |
---|---|
ExprNodeEvaluator
ExprNodeEvaluator. |
|
FilterOperator
Filter operator implementation. |
|
TableScanOperator
Table Scan Operator If the data is coming from the map-reduce framework, just forward it. |
|
UDFArgumentException
exception class, thrown when udf argument have something wrong. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.optimizer.unionproc | |
---|---|
UnionOperator
Union Operator Just forwards. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.parse | |
---|---|
AbstractMapJoinOperator
|
|
ColumnInfo
Implementation for ColumnInfo which contains the internal name for the column (the one that is used by the operator to access the column) and the type (identified by a java class). |
|
FetchTask
FetchTask implementation. |
|
GroupByOperator
GroupBy operator implementation. |
|
JoinOperator
Join operator implementation. |
|
MapJoinOperator
Map side Join operator implementation. |
|
Operator
Base operator implementation. |
|
RowSchema
RowSchema Implementation. |
|
TableScanOperator
Table Scan Operator If the data is coming from the map-reduce framework, just forward it. |
|
Task
Task implementation. |
|
UDFArgumentException
exception class, thrown when udf argument have something wrong. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.plan | |
---|---|
BucketMatcher
|
|
ColumnInfo
Implementation for ColumnInfo which contains the internal name for the column (the one that is used by the operator to access the column) and the type (identified by a java class). |
|
ListSinkOperator
For fetch task with operator tree, row read from FetchOperator is processed via operator tree and finally arrives to this operator. |
|
Operator
Base operator implementation. |
|
RecordReader
RecordReader. |
|
RecordWriter
RecordWriter. |
|
RowSchema
RowSchema Implementation. |
|
Task
Task implementation. |
|
UDFArgumentException
exception class, thrown when udf argument have something wrong. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.ppd | |
---|---|
FilterOperator
Filter operator implementation. |
|
Operator
Base operator implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.session | |
---|---|
FileSinkOperator
File Sink operator implementation. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.udf | |
---|---|
Description
Description. |
|
UDAF
Base class for all User-defined Aggregation Function (UDAF) classes. |
|
UDAFEvaluator
Interface that encapsulates the evaluation logic of a UDAF. |
|
UDF
A User-defined function (UDF) for the use with Hive. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.udf.generic | |
---|---|
Description
Description. |
|
UDAF
Base class for all User-defined Aggregation Function (UDAF) classes. |
|
UDAFEvaluator
Interface that encapsulates the evaluation logic of a UDAF. |
|
UDF
A User-defined function (UDF) for the use with Hive. |
|
UDFArgumentException
exception class, thrown when udf argument have something wrong. |
|
UDFArgumentTypeException
exception class, thrown when udf arguments have wrong types. |
|
UDTFOperator
UDTFOperator. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hadoop.hive.ql.udf.xml | |
---|---|
Description
Description. |
|
UDF
A User-defined function (UDF) for the use with Hive. |
|
UDFArgumentException
exception class, thrown when udf argument have something wrong. |
Classes in org.apache.hadoop.hive.ql.exec used by org.apache.hive.builtins | |
---|---|
Description
Description. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |