Uses of Interface
org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector

Packages that use ObjectInspector
org.apache.hadoop.hive.ql.exec Hive QL execution tasks, operators, functions and other handlers. 
org.apache.hadoop.hive.ql.exec.persistence   
org.apache.hadoop.hive.ql.io.orc The Optimized Row Columnar (ORC) File Format. 
org.apache.hadoop.hive.ql.parse   
org.apache.hadoop.hive.ql.plan   
org.apache.hadoop.hive.ql.udf   
org.apache.hadoop.hive.ql.udf.generic Standard toolkit and framework for generic User-defined functions. 
org.apache.hadoop.hive.ql.udf.ptf   
org.apache.hadoop.hive.ql.udf.xml   
org.apache.hadoop.hive.serde2   
org.apache.hadoop.hive.serde2.avro   
org.apache.hadoop.hive.serde2.binarysortable   
org.apache.hadoop.hive.serde2.columnar   
org.apache.hadoop.hive.serde2.dynamic_type   
org.apache.hadoop.hive.serde2.lazy   
org.apache.hadoop.hive.serde2.lazy.objectinspector   
org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive   
org.apache.hadoop.hive.serde2.lazybinary   
org.apache.hadoop.hive.serde2.lazybinary.objectinspector   
org.apache.hadoop.hive.serde2.objectinspector   
org.apache.hadoop.hive.serde2.objectinspector.primitive   
org.apache.hadoop.hive.serde2.thrift   
org.apache.hadoop.hive.serde2.typeinfo This package provides the implementation of the SerDe type system. 
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.exec
 

Fields in org.apache.hadoop.hive.ql.exec declared as ObjectInspector
protected  ObjectInspector[][] GroupByOperator.aggregationParameterObjectInspectors
           
protected  ObjectInspector[][] GroupByOperator.aggregationParameterStandardObjectInspectors
           
protected  ObjectInspector[] GroupByOperator.currentKeyObjectInspectors
           
protected  ObjectInspector[] Operator.inputObjInspectors
           
protected  ObjectInspector[] GroupByOperator.keyObjectInspectors
           
protected  ObjectInspector Operator.outputObjInspector
           
protected  ObjectInspector ExprNodeEvaluator.outputOI
           
protected  ObjectInspector CollectOperator.standardRowInspector
           
 

Fields in org.apache.hadoop.hive.ql.exec with type parameters of type ObjectInspector
protected  ArrayList<ObjectInspector> GroupByOperator.objectInspectors
           
 

Methods in org.apache.hadoop.hive.ql.exec that return ObjectInspector
 ObjectInspector[] Operator.getInputObjInspectors()
           
protected static
<T extends JoinDesc>
ObjectInspector
CommonJoinOperator.getJoinOutputObjectInspector(Byte[] order, List<ObjectInspector>[] aliasToObjectInspectors, T conf)
           
 ObjectInspector ColumnInfo.getObjectInspector()
           
 ObjectInspector FetchOperator.getOutputObjectInspector()
          returns output ObjectInspector, never null
 ObjectInspector MuxOperator.Handler.getOutputObjInspector()
           
 ObjectInspector ExprNodeEvaluator.getOutputOI()
          Return initialized ObjectInspector.
protected static ObjectInspector[] Operator.initEvaluators(ExprNodeEvaluator[] evals, int start, int length, ObjectInspector rowInspector)
          Initialize an array of ExprNodeEvaluator from start, for specified length and return the result ObjectInspectors.
protected static ObjectInspector[] Operator.initEvaluators(ExprNodeEvaluator[] evals, ObjectInspector rowInspector)
          Initialize an array of ExprNodeEvaluator and return the result ObjectInspectors.
 ObjectInspector ExprNodeColumnEvaluator.initialize(ObjectInspector rowInspector)
           
abstract  ObjectInspector ExprNodeEvaluator.initialize(ObjectInspector rowInspector)
          Initialize should be called once and only once.
 ObjectInspector ExprNodeGenericFuncEvaluator.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeNullEvaluator.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeFieldEvaluator.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeEvaluatorRef.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeEvaluatorHead.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeConstantEvaluator.initialize(ObjectInspector rowInspector)
           
 

Methods in org.apache.hadoop.hive.ql.exec with parameters of type ObjectInspector
 PTFPartition PTFOperator.createFirstPartitionForChain(ObjectInspector oi, HiveConf hiveConf, boolean isMapSide)
          Create a new Partition.
 void DemuxOperator.forward(Object row, ObjectInspector rowInspector)
           
protected  void Operator.forward(Object row, ObjectInspector rowInspector)
           
 void MuxOperator.forward(Object row, ObjectInspector rowInspector)
           
static List<ObjectInspector>[] JoinUtil.getObjectInspectorsFromEvaluators(List<ExprNodeEvaluator>[] exprEntries, ObjectInspector[] inputObjInspector, int posBigTableAlias, int tagLen)
           
protected static ObjectInspector[] Operator.initEvaluators(ExprNodeEvaluator[] evals, int start, int length, ObjectInspector rowInspector)
          Initialize an array of ExprNodeEvaluator from start, for specified length and return the result ObjectInspectors.
protected static ObjectInspector[] Operator.initEvaluators(ExprNodeEvaluator[] evals, ObjectInspector rowInspector)
          Initialize an array of ExprNodeEvaluator and return the result ObjectInspectors.
protected static StructObjectInspector ReduceSinkOperator.initEvaluatorsAndReturnStruct(ExprNodeEvaluator[] evals, List<List<Integer>> distinctColIndices, List<String> outputColNames, int length, ObjectInspector rowInspector)
          Initializes array of ExprNodeEvaluator.
protected static StructObjectInspector Operator.initEvaluatorsAndReturnStruct(ExprNodeEvaluator[] evals, List<String> outputColName, ObjectInspector rowInspector)
          Initialize an array of ExprNodeEvaluator and put the return values into a StructObjectInspector with integer field names.
 void Operator.initialize(Configuration hconf, ObjectInspector[] inputOIs)
          Initializes operators only if all parents have been initialized.
protected  void Operator.initialize(Configuration hconf, ObjectInspector inputOI, int parentId)
          Collects all the parent's output object inspectors and calls actual initialization method.
 ObjectInspector ExprNodeColumnEvaluator.initialize(ObjectInspector rowInspector)
           
abstract  ObjectInspector ExprNodeEvaluator.initialize(ObjectInspector rowInspector)
          Initialize should be called once and only once.
 ObjectInspector ExprNodeGenericFuncEvaluator.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeNullEvaluator.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeFieldEvaluator.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeEvaluatorRef.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeEvaluatorHead.initialize(ObjectInspector rowInspector)
           
 ObjectInspector ExprNodeConstantEvaluator.initialize(ObjectInspector rowInspector)
           
 void Operator.setInputObjInspectors(ObjectInspector[] inputObjInspectors)
           
protected  void PTFOperator.setupKeysWrapper(ObjectInspector inputOI)
           
protected  void GroupByOperator.updateAggregations(GenericUDAFEvaluator.AggregationBuffer[] aggs, Object row, ObjectInspector rowInspector, boolean hashAggr, boolean newEntryForHashAggr, Object[][] lastInvoke)
           
 

Method parameters in org.apache.hadoop.hive.ql.exec with type arguments of type ObjectInspector
static ArrayList<Object> JoinUtil.computeKeys(Object row, List<ExprNodeEvaluator> keyFields, List<ObjectInspector> keyFieldsOI)
          Return the key as a standard object.
static MapJoinKey JoinUtil.computeMapJoinKeys(MapJoinKey key, Object row, List<ExprNodeEvaluator> keyFields, List<ObjectInspector> keyFieldsOI)
          Return the key as a standard object.
static Object[] JoinUtil.computeMapJoinValues(Object row, List<ExprNodeEvaluator> valueFields, List<ObjectInspector> valueFieldsOI, List<ExprNodeEvaluator> filters, List<ObjectInspector> filtersOI, int[] filterMap)
          Return the value as a standard object.
static Object[] JoinUtil.computeMapJoinValues(Object row, List<ExprNodeEvaluator> valueFields, List<ObjectInspector> valueFieldsOI, List<ExprNodeEvaluator> filters, List<ObjectInspector> filtersOI, int[] filterMap)
          Return the value as a standard object.
static ArrayList<Object> JoinUtil.computeValues(Object row, List<ExprNodeEvaluator> valueFields, List<ObjectInspector> valueFieldsOI, boolean hasFilter)
          Return the value as a standard object.
static GenericUDAFEvaluator FunctionRegistry.getGenericUDAFEvaluator(String name, List<ObjectInspector> argumentOIs, boolean isDistinct, boolean isAllColumns)
          Get the GenericUDAF evaluator for the name and argumentClasses.
static GenericUDAFEvaluator FunctionRegistry.getGenericWindowingEvaluator(String name, List<ObjectInspector> argumentOIs, boolean isDistinct, boolean isAllColumns)
           
static RowContainer<List<Object>> JoinUtil.getRowContainer(Configuration hconf, List<ObjectInspector> structFieldObjectInspectors, Byte alias, int containerSize, TableDesc[] spillTableDesc, JoinDesc conf, boolean noFilter, Reporter reporter)
           
protected static short JoinUtil.isFiltered(Object row, List<ExprNodeEvaluator> filters, List<ObjectInspector> ois, int[] filterMap)
          Returns true if the row does not pass through filters.
 

Constructors in org.apache.hadoop.hive.ql.exec with parameters of type ObjectInspector
ColumnInfo(String internalName, ObjectInspector objectInspector, String tabAlias, boolean isVirtualCol)
           
ColumnInfo(String internalName, ObjectInspector objectInspector, String tabAlias, boolean isVirtualCol, boolean isHiddenVirtualCol)
           
KeyWrapperFactory(ExprNodeEvaluator[] keyFields, ObjectInspector[] keyObjectInspectors, ObjectInspector[] currentKeyObjectInspectors)
           
KeyWrapperFactory(ExprNodeEvaluator[] keyFields, ObjectInspector[] keyObjectInspectors, ObjectInspector[] currentKeyObjectInspectors)
           
MuxOperator.Handler(ObjectInspector inputObjInspector, List<ExprNodeDesc> keyCols, List<ExprNodeDesc> valueCols, List<String> outputKeyColumnNames, List<String> outputValueColumnNames, Integer tag)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.exec.persistence
 

Methods in org.apache.hadoop.hive.ql.exec.persistence that return ObjectInspector
 ObjectInspector MapJoinObjectSerDeContext.getStandardOI()
           
 

Methods in org.apache.hadoop.hive.ql.exec.persistence with parameters of type ObjectInspector
 void RowContainer.setSerDe(SerDe sd, ObjectInspector oi)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.io.orc
 

Methods in org.apache.hadoop.hive.ql.io.orc that return ObjectInspector
 ObjectInspector Reader.getObjectInspector()
          Get the object inspector for looking at the objects.
 ObjectInspector OrcSerde.getObjectInspector()
           
 

Methods in org.apache.hadoop.hive.ql.io.orc with parameters of type ObjectInspector
static Writer OrcFile.createWriter(FileSystem fs, Path path, Configuration conf, ObjectInspector inspector, long stripeSize, CompressionKind compress, int bufferSize, int rowIndexStride)
          Create an ORC file writer.
 OrcFile.WriterOptions OrcFile.WriterOptions.inspector(ObjectInspector value)
          A required option that sets the object inspector for the rows.
 Writable OrcSerde.serialize(Object realRow, ObjectInspector inspector)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.parse
 

Methods in org.apache.hadoop.hive.ql.parse with parameters of type ObjectInspector
protected static void PTFTranslator.validateComparable(ObjectInspector OI, String errMsg)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.plan
 

Methods in org.apache.hadoop.hive.ql.plan that return ObjectInspector
 ObjectInspector PTFDesc.ValueBoundaryDef.getOI()
           
 ObjectInspector PTFDesc.PTFExpressionDef.getOI()
           
 ObjectInspector ExprNodeGenericFuncDesc.getWritableObjectInspector()
           
 ObjectInspector ExprNodeDesc.getWritableObjectInspector()
           
 ObjectInspector ExprNodeColumnListDesc.getWritableObjectInspector()
           
 

Methods in org.apache.hadoop.hive.ql.plan with parameters of type ObjectInspector
 void PTFDesc.PTFExpressionDef.setOI(ObjectInspector oI)
           
 

Constructors in org.apache.hadoop.hive.ql.plan with parameters of type ObjectInspector
ExprNodeGenericFuncDesc(ObjectInspector oi, GenericUDF genericUDF, List<ExprNodeDesc> children)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.udf
 

Methods in org.apache.hadoop.hive.ql.udf that return ObjectInspector
 ObjectInspector GenericUDFEncode.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFDecode.initialize(ObjectInspector[] arguments)
           
 

Methods in org.apache.hadoop.hive.ql.udf with parameters of type ObjectInspector
 ObjectInspector GenericUDFEncode.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFDecode.initialize(ObjectInspector[] arguments)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.udf.generic
 

Fields in org.apache.hadoop.hive.ql.udf.generic declared as ObjectInspector
protected  ObjectInspector[] GenericUDFBaseCompare.argumentOIs
           
protected  ObjectInspector GenericUDFBaseCompare.compareOI
           
 

Methods in org.apache.hadoop.hive.ql.udf.generic that return ObjectInspector
 ObjectInspector GenericUDFUtils.ReturnObjectInspectorResolver.get()
          Returns the ObjectInspector of the return value.
 ObjectInspector GenericUDFLeadLag.getDefaultArgOI()
           
 ObjectInspector GenericUDFLeadLag.getFirstArgOI()
           
 ObjectInspector[] SimpleGenericUDAFParameterInfo.getParameterObjectInspectors()
           
 ObjectInspector[] GenericUDAFParameterInfo.getParameterObjectInspectors()
           
protected  ObjectInspector GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble.getSumFieldJavaObjectInspector()
           
protected  ObjectInspector GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal.getSumFieldJavaObjectInspector()
           
protected abstract  ObjectInspector GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator.getSumFieldJavaObjectInspector()
           
protected  ObjectInspector GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble.getSumFieldWritableObjectInspector()
           
protected  ObjectInspector GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal.getSumFieldWritableObjectInspector()
           
protected abstract  ObjectInspector GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator.getSumFieldWritableObjectInspector()
           
 ObjectInspector GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFLastValue.GenericUDAFLastValueEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFnGrams.GenericUDAFnGramEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFCollectSet.GenericUDAFMkSetEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFMin.GenericUDAFMinEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFMax.GenericUDAFMaxEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFVariance.GenericUDAFVarianceEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFCount.GenericUDAFCountEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFBridge.GenericUDAFBridgeEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFSum.GenericUDAFSumHiveDecimal.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFSum.GenericUDAFSumDouble.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFSum.GenericUDAFSumLong.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFNTile.GenericUDAFNTileEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFRank.GenericUDAFRankEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
          Initialize the evaluator.
 ObjectInspector GenericUDAFCovariance.GenericUDAFCovarianceEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDFTestGetJavaBoolean.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFEvaluateNPE.initialize(ObjectInspector[] arguments)
           
 ObjectInspector DummyContextUDF.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFTestTranslate.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFTestGetJavaString.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFStruct.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFArrayContains.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFMapKeys.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPAnd.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFEWAHBitmapEmpty.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFBetween.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFLocate.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPNotNull.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFLower.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFSortArray.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFFormatNumber.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToUnixTimeStamp.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPNull.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFPrintf.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPNot.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFNvl.initialize(ObjectInspector[] arguments)
           
abstract  ObjectInspector GenericUDF.initialize(ObjectInspector[] arguments)
          Initialize this GenericUDF.
 ObjectInspector GenericUDFConcat.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFSentences.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFConcatWS.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFLeadLag.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFInFile.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToBinary.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFArray.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFStringToMap.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFAssertTrue.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFHash.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFIn.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFUnion.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFCoalesce.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFSplit.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFMacro.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFMapValues.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToDate.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFBaseCompare.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFMap.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFElt.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFTimestamp.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFWhen.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFField.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFReflect.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFFromUtcTimestamp.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFReflect2.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFIf.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFUpper.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFIndex.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFSize.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFTranslate.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFNamedStruct.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToDecimal.initialize(ObjectInspector[] arguments)
           
 ObjectInspector AbstractGenericUDFEWAHBitmapBop.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFBridge.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFCase.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToVarchar.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPOr.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFInstr.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDF.initializeAndFoldConstants(ObjectInspector[] arguments)
          Initialize this GenericUDF.
 

Methods in org.apache.hadoop.hive.ql.udf.generic with parameters of type ObjectInspector
static int GenericUDAFRank.compare(Object[] o1, ObjectInspector[] oi1, Object[] o2, ObjectInspector[] oi2)
           
static int GenericUDAFRank.compare(Object[] o1, ObjectInspector[] oi1, Object[] o2, ObjectInspector[] oi2)
           
 Object GenericUDFUtils.ReturnObjectInspectorResolver.convertIfNecessary(Object o, ObjectInspector oi)
          Convert the return Object if necessary (when the ObjectInspectors of different possibilities are not all the same).
static Object[] GenericUDAFRank.copyToStandardObject(Object[] o, ObjectInspector[] oi, ObjectInspectorUtils.ObjectInspectorCopyOption objectInspectorOption)
           
protected  void GenericUDAFAverage.GenericUDAFAverageEvaluatorDouble.doMerge(org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AverageAggregationBuffer<Double> aggregation, Long partialCount, ObjectInspector sumFieldOI, Object partialSum)
           
protected  void GenericUDAFAverage.GenericUDAFAverageEvaluatorDecimal.doMerge(org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AverageAggregationBuffer<HiveDecimal> aggregation, Long partialCount, ObjectInspector sumFieldOI, Object partialSum)
           
protected abstract  void GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator.doMerge(org.apache.hadoop.hive.ql.udf.generic.GenericUDAFAverage.AverageAggregationBuffer<TYPE> aggregation, Long partialCount, ObjectInspector sumFieldOI, Object partialSum)
           
 ObjectInspector GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFLastValue.GenericUDAFLastValueEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFPercentileApprox.GenericUDAFSinglePercentileApproxEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFPercentileApprox.GenericUDAFMultiplePercentileApproxEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFnGrams.GenericUDAFnGramEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFCollectSet.GenericUDAFMkSetEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFMin.GenericUDAFMinEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFMax.GenericUDAFMaxEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFVariance.GenericUDAFVarianceEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFCount.GenericUDAFCountEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFBridge.GenericUDAFBridgeEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFSum.GenericUDAFSumHiveDecimal.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFSum.GenericUDAFSumDouble.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFSum.GenericUDAFSumLong.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFNTile.GenericUDAFNTileEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFRank.GenericUDAFRankEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFLongStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFDoubleStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFStringStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFComputeStats.GenericUDAFBinaryStatsEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDAFEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
          Initialize the evaluator.
 ObjectInspector GenericUDAFCovariance.GenericUDAFCovarianceEvaluator.init(GenericUDAFEvaluator.Mode m, ObjectInspector[] parameters)
           
 ObjectInspector GenericUDFTestGetJavaBoolean.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFEvaluateNPE.initialize(ObjectInspector[] arguments)
           
 ObjectInspector DummyContextUDF.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFTestTranslate.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFTestGetJavaString.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFStruct.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFArrayContains.initialize(ObjectInspector[] arguments)
           
 StructObjectInspector GenericUDTFJSONTuple.initialize(ObjectInspector[] args)
           
 ObjectInspector GenericUDFMapKeys.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPAnd.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFEWAHBitmapEmpty.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFBetween.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFLocate.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPNotNull.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFLower.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFSortArray.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFFormatNumber.initialize(ObjectInspector[] arguments)
           
 StructObjectInspector GenericUDTFParseUrlTuple.initialize(ObjectInspector[] args)
           
 ObjectInspector GenericUDFToUnixTimeStamp.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPNull.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFPrintf.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPNot.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFNvl.initialize(ObjectInspector[] arguments)
           
abstract  ObjectInspector GenericUDF.initialize(ObjectInspector[] arguments)
          Initialize this GenericUDF.
 ObjectInspector GenericUDFConcat.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFSentences.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFConcatWS.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFLeadLag.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFInFile.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToBinary.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFArray.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFStringToMap.initialize(ObjectInspector[] arguments)
           
 StructObjectInspector GenericUDTFInline.initialize(ObjectInspector[] ois)
           
 ObjectInspector GenericUDFAssertTrue.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFHash.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFIn.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFUnion.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFCoalesce.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFSplit.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFMacro.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFMapValues.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToDate.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFBaseCompare.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFMap.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFElt.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFTimestamp.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFWhen.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFField.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFReflect.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFFromUtcTimestamp.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFReflect2.initialize(ObjectInspector[] arguments)
           
 StructObjectInspector GenericUDTFExplode.initialize(ObjectInspector[] args)
           
 ObjectInspector GenericUDFIf.initialize(ObjectInspector[] arguments)
           
 StructObjectInspector GenericUDTFStack.initialize(ObjectInspector[] args)
           
 ObjectInspector GenericUDFUpper.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFIndex.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFSize.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFTranslate.initialize(ObjectInspector[] arguments)
           
abstract  StructObjectInspector GenericUDTF.initialize(ObjectInspector[] argOIs)
          Initialize this GenericUDTF.
 ObjectInspector GenericUDFNamedStruct.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToDecimal.initialize(ObjectInspector[] arguments)
           
 ObjectInspector AbstractGenericUDFEWAHBitmapBop.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFBridge.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFCase.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFToVarchar.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFOPOr.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDFInstr.initialize(ObjectInspector[] arguments)
           
 ObjectInspector GenericUDF.initializeAndFoldConstants(ObjectInspector[] arguments)
          Initialize this GenericUDF.
protected  void GenericUDFToUnixTimeStamp.initializeInput(ObjectInspector[] arguments)
           
protected  void GenericUDFUnixTimeStamp.initializeInput(ObjectInspector[] arguments)
           
protected  boolean GenericUDFConcatWS.isStringOrVoidType(ObjectInspector oi)
           
 void GenericUDFLeadLag.setDefaultArgOI(ObjectInspector defaultArgOI)
           
 void GenericUDFLeadLag.setFirstArgOI(ObjectInspector firstArgOI)
           
 boolean GenericUDFUtils.ReturnObjectInspectorResolver.update(ObjectInspector oi)
          Update returnObjectInspector and valueInspectorsAreTheSame based on the ObjectInspector seen.
 

Constructors in org.apache.hadoop.hive.ql.udf.generic with parameters of type ObjectInspector
GenericUDFUtils.ConversionHelper(Method m, ObjectInspector[] parameterOIs)
          Create a PrimitiveConversionHelper for Method m.
SimpleGenericUDAFParameterInfo(ObjectInspector[] params, boolean distinct, boolean allColumns)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.udf.ptf
 

Methods in org.apache.hadoop.hive.ql.udf.ptf with parameters of type ObjectInspector
static ArrayList<Object> MatchPath.getPath(Object currRow, ObjectInspector rowOI, PTFPartition.PTFPartitionIterator<Object> pItr, int sz)
           
static Object MatchPath.getSelectListInput(Object currRow, ObjectInspector rowOI, PTFPartition.PTFPartitionIterator<Object> pItr, int sz)
           
 

Constructors in org.apache.hadoop.hive.ql.udf.ptf with parameters of type ObjectInspector
MatchPath.Symbol(ExprNodeEvaluator symbolExprEval, ObjectInspector symbolOI)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.udf.ptf with type arguments of type ObjectInspector
MatchPath.SymbolParser(String patternStr, ArrayList<String> symbolNames, ArrayList<ExprNodeEvaluator> symbolExprEvals, ArrayList<ObjectInspector> symbolExprOIs)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.ql.udf.xml
 

Methods in org.apache.hadoop.hive.ql.udf.xml that return ObjectInspector
 ObjectInspector GenericUDFXPath.initialize(ObjectInspector[] arguments)
           
 

Methods in org.apache.hadoop.hive.ql.udf.xml with parameters of type ObjectInspector
 ObjectInspector GenericUDFXPath.initialize(ObjectInspector[] arguments)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2
 

Classes in org.apache.hadoop.hive.serde2 that implement ObjectInspector
 class CustomNonSettableListObjectInspector1
           
 class CustomNonSettableStructObjectInspector1
           
static class NullStructSerDe.NullStructSerDeObjectInspector
          A object inspector for null struct serde.
 

Fields in org.apache.hadoop.hive.serde2 declared as ObjectInspector
protected  ObjectInspector CustomNonSettableStructObjectInspector1.MyField.fieldObjectInspector
           
 

Methods in org.apache.hadoop.hive.serde2 that return ObjectInspector
 ObjectInspector CustomNonSettableStructObjectInspector1.MyField.getFieldObjectInspector()
           
 ObjectInspector CustomNonSettableListObjectInspector1.getListElementObjectInspector()
           
 ObjectInspector CustomSerDe1.getObjectInspector()
           
 ObjectInspector CustomSerDe2.getObjectInspector()
           
 ObjectInspector TestSerDe.getObjectInspector()
           
 ObjectInspector RegexSerDe.getObjectInspector()
           
 ObjectInspector MetadataTypedColumnsetSerDe.getObjectInspector()
           
 ObjectInspector Deserializer.getObjectInspector()
          Deprecated. Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...).
abstract  ObjectInspector AbstractDeserializer.getObjectInspector()
          Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...).
 ObjectInspector NullStructSerDe.getObjectInspector()
           
 ObjectInspector TypedSerDe.getObjectInspector()
           
abstract  ObjectInspector AbstractSerDe.getObjectInspector()
          Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...).
 

Methods in org.apache.hadoop.hive.serde2 with parameters of type ObjectInspector
static String SerDeUtils.getJSONString(Object o, ObjectInspector oi)
           
static String SerDeUtils.getJSONString(Object o, ObjectInspector oi, String nullStr)
          Use this if you need to have custom representation of top level null .
static boolean SerDeUtils.hasAnyNullObject(Object o, ObjectInspector oi)
          True if Object passed is representing null object.
 Writable CustomSerDe1.serialize(Object obj, ObjectInspector objInspector)
           
 Writable CustomSerDe2.serialize(Object obj, ObjectInspector objInspector)
           
 Writable TestSerDe.serialize(Object obj, ObjectInspector objInspector)
           
 Writable RegexSerDe.serialize(Object obj, ObjectInspector objInspector)
           
 Writable Serializer.serialize(Object obj, ObjectInspector objInspector)
          Deprecated. Serialize an object by navigating inside the Object with the ObjectInspector.
 Writable MetadataTypedColumnsetSerDe.serialize(Object obj, ObjectInspector objInspector)
           
abstract  Writable AbstractSerializer.serialize(Object obj, ObjectInspector objInspector)
          Serialize an object by navigating inside the Object with the ObjectInspector.
 Writable NullStructSerDe.serialize(Object obj, ObjectInspector objInspector)
           
 Writable TypedSerDe.serialize(Object obj, ObjectInspector objInspector)
           
abstract  Writable AbstractSerDe.serialize(Object obj, ObjectInspector objInspector)
          Serialize an object by navigating inside the Object with the ObjectInspector.
protected  void DelimitedJSONSerDe.serializeField(ByteStream.Output out, Object obj, ObjectInspector objInspector, LazySimpleSerDe.SerDeParameters serdeParams)
           
 

Method parameters in org.apache.hadoop.hive.serde2 with type arguments of type ObjectInspector
protected  void CustomNonSettableStructObjectInspector1.init(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors)
           
 

Constructors in org.apache.hadoop.hive.serde2 with parameters of type ObjectInspector
CustomNonSettableListObjectInspector1(ObjectInspector listElementObjectInspector)
           
CustomNonSettableStructObjectInspector1.MyField(int fieldID, String fieldName, ObjectInspector fieldObjectInspector)
           
CustomNonSettableStructObjectInspector1.MyField(int fieldID, String fieldName, ObjectInspector fieldObjectInspector, String fieldComment)
           
 

Constructor parameters in org.apache.hadoop.hive.serde2 with type arguments of type ObjectInspector
CustomNonSettableStructObjectInspector1(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors)
          Call ObjectInspectorFactory.getNonSettableStructObjectInspector instead.
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.avro
 

Methods in org.apache.hadoop.hive.serde2.avro that return ObjectInspector
 ObjectInspector AvroSerDe.getObjectInspector()
           
 

Methods in org.apache.hadoop.hive.serde2.avro with parameters of type ObjectInspector
 Writable AvroSerDe.serialize(Object o, ObjectInspector objectInspector)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.binarysortable
 

Methods in org.apache.hadoop.hive.serde2.binarysortable that return ObjectInspector
 ObjectInspector BinarySortableSerDe.getObjectInspector()
           
 

Methods in org.apache.hadoop.hive.serde2.binarysortable with parameters of type ObjectInspector
 Writable BinarySortableSerDe.serialize(Object obj, ObjectInspector objInspector)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.columnar
 

Fields in org.apache.hadoop.hive.serde2.columnar declared as ObjectInspector
protected  ObjectInspector ColumnarSerDeBase.cachedObjectInspector
           
 

Methods in org.apache.hadoop.hive.serde2.columnar that return ObjectInspector
 ObjectInspector ColumnarSerDeBase.getObjectInspector()
           
 

Methods in org.apache.hadoop.hive.serde2.columnar with parameters of type ObjectInspector
protected  LazyObjectBase LazyBinaryColumnarStruct.createLazyObjectBase(ObjectInspector objectInspector)
           
protected  LazyObjectBase ColumnarStruct.createLazyObjectBase(ObjectInspector objectInspector)
           
protected abstract  LazyObjectBase ColumnarStructBase.createLazyObjectBase(ObjectInspector objectInspector)
          create the lazy object for this field
protected  int LazyBinaryColumnarStruct.getLength(ObjectInspector objectInspector, ByteArrayRef cachedByteArrayRef, int start, int length)
           
protected  int ColumnarStruct.getLength(ObjectInspector objectInspector, ByteArrayRef cachedByteArrayRef, int start, int fieldLen)
           
protected abstract  int ColumnarStructBase.getLength(ObjectInspector objectInspector, ByteArrayRef cachedByteArrayRef, int start, int length)
          Check if the object is null and return the length of the stream
 Writable LazyBinaryColumnarSerDe.serialize(Object obj, ObjectInspector objInspector)
           
 Writable ColumnarSerDe.serialize(Object obj, ObjectInspector objInspector)
          Serialize a row of data.
 

Constructors in org.apache.hadoop.hive.serde2.columnar with parameters of type ObjectInspector
ColumnarStruct(ObjectInspector oi)
          Construct a ColumnarStruct object with the TypeInfo.
ColumnarStruct(ObjectInspector oi, ArrayList<Integer> notSkippedColumnIDs, Text nullSequence)
          Construct a ColumnarStruct object with the TypeInfo.
ColumnarStructBase(ObjectInspector oi, ArrayList<Integer> notSkippedColumnIDs)
           
LazyBinaryColumnarStruct(ObjectInspector oi, ArrayList<Integer> notSkippedColumnIDs)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.dynamic_type
 

Methods in org.apache.hadoop.hive.serde2.dynamic_type that return ObjectInspector
static ObjectInspector DynamicSerDe.dynamicSerDeStructBaseToObjectInspector(DynamicSerDeTypeBase bt)
           
 ObjectInspector DynamicSerDe.getObjectInspector()
           
 

Methods in org.apache.hadoop.hive.serde2.dynamic_type with parameters of type ObjectInspector
 Writable DynamicSerDe.serialize(Object obj, ObjectInspector objInspector)
           
 void DynamicSerDeTypeList.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypei32.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypeSet.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
abstract  void DynamicSerDeTypeBase.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypeDouble.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypei16.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypeString.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypeBool.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeStructBase.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
          serialize The way to serialize a Thrift "table" which in thrift land is really a function and thus this class's name.
 void DynamicSerDeFieldList.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypeByte.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypeMap.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypei64.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 void DynamicSerDeTypedef.serialize(Object o, ObjectInspector oi, org.apache.thrift.protocol.TProtocol oprot)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.lazy
 

Classes in org.apache.hadoop.hive.serde2.lazy with type parameters of type ObjectInspector
 class LazyNonPrimitive<OI extends ObjectInspector>
          LazyPrimitive stores a primitive Object in a LazyObject.
 class LazyObject<OI extends ObjectInspector>
          LazyObject stores an object in a range of bytes in a byte[].
 class LazyPrimitive<OI extends ObjectInspector,T extends Writable>
          LazyPrimitive stores a primitive Object in a LazyObject.
 

Fields in org.apache.hadoop.hive.serde2.lazy declared as ObjectInspector
protected  OI LazyObject.oi
           
 

Methods in org.apache.hadoop.hive.serde2.lazy that return ObjectInspector
static ObjectInspector LazyFactory.createColumnarStructInspector(List<String> columnNames, List<TypeInfo> columnTypes, byte[] separators, Text nullSequence, boolean escaped, byte escapeChar)
          Create a hierarchical ObjectInspector for ColumnarStruct with the given columnNames and columnTypeInfos.
static ObjectInspector LazyFactory.createLazyObjectInspector(TypeInfo typeInfo, byte[] separator, int separatorIndex, Text nullSequence, boolean escaped, byte escapeChar)
          Create a hierarchical ObjectInspector for LazyObject with the given typeInfo.
static ObjectInspector LazyFactory.createLazyStructInspector(List<String> columnNames, List<TypeInfo> typeInfos, byte[] separators, Text nullSequence, boolean lastColumnTakesRest, boolean escaped, byte escapeChar)
          Create a hierarchical ObjectInspector for LazyStruct with the given columnNames and columnTypeInfos.
 ObjectInspector LazySimpleSerDe.getObjectInspector()
          Returns the ObjectInspector for the row.
 

Methods in org.apache.hadoop.hive.serde2.lazy that return types with arguments of type ObjectInspector
static LazyObject<? extends ObjectInspector> LazyFactory.createLazyObject(ObjectInspector oi)
          Create a hierarchical LazyObject based on the given typeInfo.
static LazyObject<? extends ObjectInspector> LazyFactory.createLazyObject(ObjectInspector oi, boolean typeBinary)
          Creates a LazyObject based on the LazyObjectInspector.
static LazyPrimitive<? extends ObjectInspector,? extends Writable> LazyFactory.createLazyPrimitiveBinaryClass(PrimitiveObjectInspector poi)
           
static LazyPrimitive<? extends ObjectInspector,? extends Writable> LazyFactory.createLazyPrimitiveClass(PrimitiveObjectInspector oi)
          Create a lazy primitive class given the type name.
static LazyPrimitive<? extends ObjectInspector,? extends Writable> LazyFactory.createLazyPrimitiveClass(PrimitiveObjectInspector poi, boolean typeBinary)
          Create a lazy primitive object instance given a primitive object inspector based on it's type.
 

Methods in org.apache.hadoop.hive.serde2.lazy with parameters of type ObjectInspector
static LazyObject<? extends ObjectInspector> LazyFactory.createLazyObject(ObjectInspector oi)
          Create a hierarchical LazyObject based on the given typeInfo.
static LazyObject<? extends ObjectInspector> LazyFactory.createLazyObject(ObjectInspector oi, boolean typeBinary)
          Creates a LazyObject based on the LazyObjectInspector.
static void LazySimpleSerDe.serialize(ByteStream.Output out, Object obj, ObjectInspector objInspector, byte[] separators, int level, Text nullSequence, boolean escaped, byte escapeChar, boolean[] needsEscape)
          Serialize the row into the StringBuilder.
 Writable LazySimpleSerDe.serialize(Object obj, ObjectInspector objInspector)
          Serialize a row of data.
protected  void LazySimpleSerDe.serializeField(ByteStream.Output out, Object obj, ObjectInspector objInspector, LazySimpleSerDe.SerDeParameters serdeParams)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.lazy.objectinspector
 

Classes in org.apache.hadoop.hive.serde2.lazy.objectinspector that implement ObjectInspector
 class LazyListObjectInspector
          LazyListObjectInspector works on array data that is stored in LazyArray.
 class LazyMapObjectInspector
          LazyMapObjectInspector works on struct data that is stored in LazyStruct.
 class LazySimpleStructObjectInspector
          LazySimpleStructObjectInspector works on struct data that is stored in LazyStruct.
 class LazyUnionObjectInspector
          LazyUnionObjectInspector works on union data that is stored in LazyUnion.
 

Fields in org.apache.hadoop.hive.serde2.lazy.objectinspector declared as ObjectInspector
protected  ObjectInspector LazySimpleStructObjectInspector.MyField.fieldObjectInspector
           
 

Fields in org.apache.hadoop.hive.serde2.lazy.objectinspector with type parameters of type ObjectInspector
protected  List<ObjectInspector> LazyUnionObjectInspector.ois
           
 

Methods in org.apache.hadoop.hive.serde2.lazy.objectinspector that return ObjectInspector
 ObjectInspector LazySimpleStructObjectInspector.MyField.getFieldObjectInspector()
           
 ObjectInspector LazyListObjectInspector.getListElementObjectInspector()
           
 ObjectInspector LazyMapObjectInspector.getMapKeyObjectInspector()
           
 ObjectInspector LazyMapObjectInspector.getMapValueObjectInspector()
           
 

Methods in org.apache.hadoop.hive.serde2.lazy.objectinspector that return types with arguments of type ObjectInspector
 List<ObjectInspector> LazyUnionObjectInspector.getObjectInspectors()
           
 

Methods in org.apache.hadoop.hive.serde2.lazy.objectinspector with parameters of type ObjectInspector
static LazyListObjectInspector LazyObjectInspectorFactory.getLazySimpleListObjectInspector(ObjectInspector listElementObjectInspector, byte separator, Text nullSequence, boolean escaped, byte escapeChar)
           
static LazyMapObjectInspector LazyObjectInspectorFactory.getLazySimpleMapObjectInspector(ObjectInspector mapKeyObjectInspector, ObjectInspector mapValueObjectInspector, byte itemSeparator, byte keyValueSeparator, Text nullSequence, boolean escaped, byte escapeChar)
           
 

Method parameters in org.apache.hadoop.hive.serde2.lazy.objectinspector with type arguments of type ObjectInspector
static LazySimpleStructObjectInspector LazyObjectInspectorFactory.getLazySimpleStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, byte separator, Text nullSequence, boolean lastColumnTakesRest, boolean escaped, byte escapeChar)
           
static LazySimpleStructObjectInspector LazyObjectInspectorFactory.getLazySimpleStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structFieldComments, byte separator, Text nullSequence, boolean lastColumnTakesRest, boolean escaped, byte escapeChar)
           
static LazyUnionObjectInspector LazyObjectInspectorFactory.getLazyUnionObjectInspector(List<ObjectInspector> ois, byte separator, Text nullSequence, boolean escaped, byte escapeChar)
           
protected  void LazyUnionObjectInspector.init(List<ObjectInspector> ois, byte separator, Text nullSequence)
           
protected  void LazyUnionObjectInspector.init(List<ObjectInspector> ois, byte separator, Text nullSequence, boolean escaped, byte escapeChar)
           
protected  void LazySimpleStructObjectInspector.init(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structFieldComments, byte separator, Text nullSequence, boolean lastColumnTakesRest, boolean escaped, byte escapeChar)
           
 

Constructors in org.apache.hadoop.hive.serde2.lazy.objectinspector with parameters of type ObjectInspector
LazyListObjectInspector(ObjectInspector listElementObjectInspector, byte separator, Text nullSequence, boolean escaped, byte escapeChar)
          Call ObjectInspectorFactory.getLazySimpleListObjectInspector instead.
LazyMapObjectInspector(ObjectInspector mapKeyObjectInspector, ObjectInspector mapValueObjectInspector, byte itemSeparator, byte keyValueSeparator, Text nullSequence, boolean escaped, byte escapeChar)
          Call ObjectInspectorFactory.getStandardListObjectInspector instead.
LazySimpleStructObjectInspector.MyField(int fieldID, String fieldName, ObjectInspector fieldObjectInspector)
           
LazySimpleStructObjectInspector.MyField(int fieldID, String fieldName, ObjectInspector fieldObjectInspector, String fieldComment)
           
 

Constructor parameters in org.apache.hadoop.hive.serde2.lazy.objectinspector with type arguments of type ObjectInspector
LazySimpleStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, byte separator, Text nullSequence, boolean lastColumnTakesRest, boolean escaped, byte escapeChar)
          Call ObjectInspectorFactory.getLazySimpleStructObjectInspector instead.
LazySimpleStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structFieldComments, byte separator, Text nullSequence, boolean lastColumnTakesRest, boolean escaped, byte escapeChar)
           
LazyUnionObjectInspector(List<ObjectInspector> ois, byte separator, Text nullSequence)
           
LazyUnionObjectInspector(List<ObjectInspector> ois, byte separator, Text nullSequence, boolean escaped, byte escapeChar)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive
 

Classes in org.apache.hadoop.hive.serde2.lazy.objectinspector.primitive that implement ObjectInspector
 class AbstractPrimitiveLazyObjectInspector<T extends Writable>
          An AbstractPrimitiveLazyObjectInspector for a LazyPrimitive object.
 class LazyBinaryObjectInspector
           
 class LazyBooleanObjectInspector
          A WritableBooleanObjectInspector inspects a BooleanWritable Object.
 class LazyByteObjectInspector
          A WritableByteObjectInspector inspects a ByteWritable Object.
 class LazyDateObjectInspector
          A WritableDateObjectInspector inspects a DateWritable Object.
 class LazyDoubleObjectInspector
          A WritableDoubleObjectInspector inspects a DoubleWritable Object.
 class LazyFloatObjectInspector
          A FloatObjectInspector inspects a FloatWritable Object.
 class LazyHiveDecimalObjectInspector
           
 class LazyHiveVarcharObjectInspector
           
 class LazyIntObjectInspector
          A WritableIntObjectInspector inspects a IntWritable Object.
 class LazyLongObjectInspector
          A WritableLongObjectInspector inspects a LongWritable Object.
 class LazyShortObjectInspector
          A WritableShortObjectInspector inspects a ShortWritable Object.
 class LazyStringObjectInspector
          A WritableStringObjectInspector inspects a Text Object.
 class LazyTimestampObjectInspector
           
 class LazyVoidObjectInspector
          A WritableVoidObjectInspector inspects a NullWritable Object.
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.lazybinary
 

Classes in org.apache.hadoop.hive.serde2.lazybinary with type parameters of type ObjectInspector
 class LazyBinaryNonPrimitive<OI extends ObjectInspector>
          LazyBinaryNonPrimitive.
 class LazyBinaryObject<OI extends ObjectInspector>
          LazyBinaryObject stores an object in a binary format in a byte[].
 class LazyBinaryPrimitive<OI extends ObjectInspector,T extends Writable>
          Defines a LazyBinaryPrimitive.
 

Methods in org.apache.hadoop.hive.serde2.lazybinary that return ObjectInspector
static ObjectInspector LazyBinaryFactory.createColumnarStructInspector(List<String> columnNames, List<TypeInfo> columnTypes)
           
static ObjectInspector LazyBinaryUtils.getLazyBinaryObjectInspectorFromTypeInfo(TypeInfo typeInfo)
          Returns the lazy binary object inspector that can be used to inspect an lazy binary object of that typeInfo For primitive types, we use the standard writable object inspector.
 ObjectInspector LazyBinarySerDe.getObjectInspector()
          Returns the ObjectInspector for the row.
 

Methods in org.apache.hadoop.hive.serde2.lazybinary with parameters of type ObjectInspector
static void LazyBinaryUtils.checkObjectByteInfo(ObjectInspector objectInspector, byte[] bytes, int offset, LazyBinaryUtils.RecordInfo recordInfo)
          Check a particular field and set its size and offset in bytes based on the field type and the bytes arrays.
static LazyBinaryObject LazyBinaryFactory.createLazyBinaryObject(ObjectInspector oi)
          Create a hierarchical LazyBinaryObject based on the given typeInfo.
static boolean LazyBinarySerDe.serialize(ByteStream.Output byteStream, Object obj, ObjectInspector objInspector, boolean skipLengthPrefix, boolean warnedOnceNullMapKey)
          A recursive function that serialize an object to a byte buffer based on its object inspector.
 Writable LazyBinarySerDe.serialize(Object obj, ObjectInspector objInspector)
          Serialize an object to a byte buffer in a binary compact way.
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.lazybinary.objectinspector
 

Classes in org.apache.hadoop.hive.serde2.lazybinary.objectinspector that implement ObjectInspector
 class LazyBinaryListObjectInspector
          ObjectInspector for LazyBinaryList.
 class LazyBinaryMapObjectInspector
          ObjectInspector for LazyBinaryMap.
 class LazyBinaryStructObjectInspector
          ObjectInspector for LazyBinaryStruct.
 

Methods in org.apache.hadoop.hive.serde2.lazybinary.objectinspector with parameters of type ObjectInspector
static LazyBinaryListObjectInspector LazyBinaryObjectInspectorFactory.getLazyBinaryListObjectInspector(ObjectInspector listElementObjectInspector)
           
static LazyBinaryMapObjectInspector LazyBinaryObjectInspectorFactory.getLazyBinaryMapObjectInspector(ObjectInspector mapKeyObjectInspector, ObjectInspector mapValueObjectInspector)
           
 

Method parameters in org.apache.hadoop.hive.serde2.lazybinary.objectinspector with type arguments of type ObjectInspector
static LazyBinaryStructObjectInspector LazyBinaryObjectInspectorFactory.getLazyBinaryStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors)
           
static LazyBinaryStructObjectInspector LazyBinaryObjectInspectorFactory.getLazyBinaryStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structFieldComments)
           
 

Constructors in org.apache.hadoop.hive.serde2.lazybinary.objectinspector with parameters of type ObjectInspector
LazyBinaryListObjectInspector(ObjectInspector listElementObjectInspector)
           
LazyBinaryMapObjectInspector(ObjectInspector mapKeyObjectInspector, ObjectInspector mapValueObjectInspector)
           
 

Constructor parameters in org.apache.hadoop.hive.serde2.lazybinary.objectinspector with type arguments of type ObjectInspector
LazyBinaryStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors)
           
LazyBinaryStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structFieldComments)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.objectinspector
 

Subinterfaces of ObjectInspector in org.apache.hadoop.hive.serde2.objectinspector
 interface ConstantObjectInspector
          ConstantObjectInspector.
 interface ListObjectInspector
          ListObjectInspector.
 interface MapObjectInspector
          MapObjectInspector.
 interface PrimitiveObjectInspector
          PrimitiveObjectInspector.
 interface SettableListObjectInspector
          SettableListObjectInspector.
 interface SettableMapObjectInspector
          SettableMapObjectInspector.
 interface UnionObjectInspector
          UnionObjectInspector works on union data that is stored as UnionObject.
 

Classes in org.apache.hadoop.hive.serde2.objectinspector that implement ObjectInspector
 class DelegatedListObjectInspector
           
 class DelegatedMapObjectInspector
           
 class DelegatedStructObjectInspector
           
 class DelegatedUnionObjectInspector
           
 class MetadataListStructObjectInspector
          StructObjectInspector works on struct data that is stored as a Java List or Java Array object.
 class ReflectionStructObjectInspector
          ReflectionStructObjectInspector works on struct data that is stored as a native Java object.
 class SettableStructObjectInspector
          SettableStructObjectInspector.
 class StandardConstantListObjectInspector
          A StandardListObjectInspector which also implements the ConstantObjectInspector interface.
 class StandardConstantMapObjectInspector
          A StandardMapObjectInspector which also implements the ConstantObjectInspector interface.
 class StandardListObjectInspector
          DefaultListObjectInspector works on list data that is stored as a Java List or Java Array object.
 class StandardMapObjectInspector
          StandardMapObjectInspector works on map data that is stored as a Java Map object.
 class StandardStructObjectInspector
          ListStructObjectInspector works on struct data that is stored as a Java List or Java Array object.
 class StandardUnionObjectInspector
          StandardUnionObjectInspector works on union data that is stored as UnionObject.
 class StructObjectInspector
          StructObjectInspector.
 class 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 inspector, it will mask out some fields in the row as if they are not there.
 class UnionStructObjectInspector
          UnionStructObjectInspector unions several struct data into a single struct.
 

Fields in org.apache.hadoop.hive.serde2.objectinspector declared as ObjectInspector
protected  ObjectInspector ReflectionStructObjectInspector.MyField.fieldObjectInspector
           
protected  ObjectInspector StandardStructObjectInspector.MyField.fieldObjectInspector
           
 ObjectInspector InspectableObject.oi
           
 

Methods in org.apache.hadoop.hive.serde2.objectinspector that return ObjectInspector
static ObjectInspector ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI, ObjectInspector outputOI, boolean equalsCheck)
           
 ObjectInspector ReflectionStructObjectInspector.MyField.getFieldObjectInspector()
           
 ObjectInspector UnionStructObjectInspector.MyField.getFieldObjectInspector()
           
 ObjectInspector StructField.getFieldObjectInspector()
          Get the ObjectInspector for the field.
 ObjectInspector StandardStructObjectInspector.MyField.getFieldObjectInspector()
           
 ObjectInspector DelegatedListObjectInspector.getListElementObjectInspector()
           
 ObjectInspector ListObjectInspector.getListElementObjectInspector()
           
 ObjectInspector StandardListObjectInspector.getListElementObjectInspector()
           
 ObjectInspector DelegatedMapObjectInspector.getMapKeyObjectInspector()
           
 ObjectInspector StandardMapObjectInspector.getMapKeyObjectInspector()
           
 ObjectInspector MapObjectInspector.getMapKeyObjectInspector()
           
 ObjectInspector DelegatedMapObjectInspector.getMapValueObjectInspector()
           
 ObjectInspector StandardMapObjectInspector.getMapValueObjectInspector()
           
 ObjectInspector MapObjectInspector.getMapValueObjectInspector()
           
static ObjectInspector ObjectInspectorFactory.getReflectionObjectInspector(Type t, ObjectInspectorFactory.ObjectInspectorOptions options)
           
static ObjectInspector ObjectInspectorUtils.getStandardObjectInspector(ObjectInspector oi)
          Get the corresponding standard ObjectInspector for an ObjectInspector.
static ObjectInspector ObjectInspectorUtils.getStandardObjectInspector(ObjectInspector oi, ObjectInspectorUtils.ObjectInspectorCopyOption objectInspectorOption)
           
static ObjectInspector ObjectInspectorUtils.getWritableObjectInspector(ObjectInspector oi)
          Ensures that an ObjectInspector is Writable.
static ObjectInspector DelegatedObjectInspectorFactory.reset(ObjectInspector prev, ObjectInspector current)
           
static ObjectInspector DelegatedObjectInspectorFactory.wrap(ObjectInspector inspector)
           
 

Methods in org.apache.hadoop.hive.serde2.objectinspector that return types with arguments of type ObjectInspector
 List<ObjectInspector> DelegatedUnionObjectInspector.getObjectInspectors()
           
 List<ObjectInspector> StandardUnionObjectInspector.getObjectInspectors()
           
 List<ObjectInspector> UnionObjectInspector.getObjectInspectors()
          Returns the array of ObjectInspectors that are for each of the tags.
 

Methods in org.apache.hadoop.hive.serde2.objectinspector with parameters of type ObjectInspector
static int ObjectInspectorUtils.compare(Object[] o1, ObjectInspector[] oi1, Object[] o2, ObjectInspector[] oi2)
          Compare two arrays of objects with their respective arrays of ObjectInspectors.
static int ObjectInspectorUtils.compare(Object[] o1, ObjectInspector[] oi1, Object[] o2, ObjectInspector[] oi2)
          Compare two arrays of objects with their respective arrays of ObjectInspectors.
static int ObjectInspectorUtils.compare(Object o1, ObjectInspector oi1, Object o2, ObjectInspector oi2)
          Compare two objects with their respective ObjectInspectors.
static int ObjectInspectorUtils.compare(Object o1, ObjectInspector oi1, Object o2, ObjectInspector oi2, MapEqualComparer mapEqualComparer)
          Compare two objects with their respective ObjectInspectors.
static boolean ObjectInspectorUtils.compareSupported(ObjectInspector oi)
          Whether comparison is supported for this type.
static boolean ObjectInspectorUtils.compareTypes(ObjectInspector o1, ObjectInspector o2)
          Compares two types identified by the given object inspectors.
static Object ObjectInspectorUtils.copyToStandardJavaObject(Object o, ObjectInspector oi)
           
static Object ObjectInspectorUtils.copyToStandardObject(Object o, ObjectInspector oi)
          Returns a deep copy of the Object o that can be scanned by a StandardObjectInspector returned by getStandardObjectInspector(oi).
static Object ObjectInspectorUtils.copyToStandardObject(Object o, ObjectInspector oi, ObjectInspectorUtils.ObjectInspectorCopyOption objectInspectorOption)
           
static ConstantObjectInspector ObjectInspectorUtils.getConstantObjectInspector(ObjectInspector oi, Object value)
           
static ObjectInspector ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI, ObjectInspector outputOI, boolean equalsCheck)
           
static ObjectInspectorConverters.Converter ObjectInspectorConverters.getConverter(ObjectInspector inputOI, ObjectInspector outputOI)
          Returns a converter that converts objects from one OI to another OI.
static String ObjectInspectorUtils.getObjectInspectorName(ObjectInspector oi)
          Get the class names of the ObjectInspector hierarchy.
static StandardConstantListObjectInspector ObjectInspectorFactory.getStandardConstantListObjectInspector(ObjectInspector listElementObjectInspector, List<?> constantValue)
           
static StandardConstantMapObjectInspector ObjectInspectorFactory.getStandardConstantMapObjectInspector(ObjectInspector mapKeyObjectInspector, ObjectInspector mapValueObjectInspector, Map<?,?> constantValue)
           
static StandardListObjectInspector ObjectInspectorFactory.getStandardListObjectInspector(ObjectInspector listElementObjectInspector)
           
static StandardMapObjectInspector ObjectInspectorFactory.getStandardMapObjectInspector(ObjectInspector mapKeyObjectInspector, ObjectInspector mapValueObjectInspector)
           
static ObjectInspector ObjectInspectorUtils.getStandardObjectInspector(ObjectInspector oi)
          Get the corresponding standard ObjectInspector for an ObjectInspector.
static ObjectInspector ObjectInspectorUtils.getStandardObjectInspector(ObjectInspector oi, ObjectInspectorUtils.ObjectInspectorCopyOption objectInspectorOption)
           
static Object ObjectInspectorUtils.getWritableConstantValue(ObjectInspector oi)
           
static ObjectInspector ObjectInspectorUtils.getWritableObjectInspector(ObjectInspector oi)
          Ensures that an ObjectInspector is Writable.
static int ObjectInspectorUtils.hashCode(Object o, ObjectInspector objIns)
           
static boolean ObjectInspectorUtils.isConstantObjectInspector(ObjectInspector oi)
           
static ObjectInspector DelegatedObjectInspectorFactory.reset(ObjectInspector prev, ObjectInspector current)
           
static boolean ObjectInspectorUtils.supportsConstantObjectInspector(ObjectInspector oi)
           
static ObjectInspector DelegatedObjectInspectorFactory.wrap(ObjectInspector inspector)
           
 

Method parameters in org.apache.hadoop.hive.serde2.objectinspector with type arguments of type ObjectInspector
static org.apache.hadoop.hive.serde2.objectinspector.ColumnarStructObjectInspector ObjectInspectorFactory.getColumnarStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors)
           
static org.apache.hadoop.hive.serde2.objectinspector.ColumnarStructObjectInspector ObjectInspectorFactory.getColumnarStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structFieldComments)
           
static StandardStructObjectInspector ObjectInspectorFactory.getStandardStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors)
           
static StandardStructObjectInspector ObjectInspectorFactory.getStandardStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structComments)
           
static StandardUnionObjectInspector ObjectInspectorFactory.getStandardUnionObjectInspector(List<ObjectInspector> unionObjectInspectors)
           
protected  void StandardStructObjectInspector.init(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structFieldComments)
           
 

Constructors in org.apache.hadoop.hive.serde2.objectinspector with parameters of type ObjectInspector
InspectableObject(Object o, ObjectInspector oi)
           
ListObjectsEqualComparer(ObjectInspector[] oi0, ObjectInspector[] oi1)
           
ListObjectsEqualComparer(ObjectInspector[] oi0, ObjectInspector[] oi1)
           
ObjectInspectorConverters.ListConverter(ObjectInspector inputOI, SettableListObjectInspector outputOI)
           
ObjectInspectorConverters.MapConverter(ObjectInspector inputOI, SettableMapObjectInspector outputOI)
           
ObjectInspectorConverters.StructConverter(ObjectInspector inputOI, SettableStructObjectInspector outputOI)
           
ReflectionStructObjectInspector.MyField(Field field, ObjectInspector fieldObjectInspector)
           
StandardConstantListObjectInspector(ObjectInspector listElementObjectInspector, List<?> value)
          Call ObjectInspectorFactory.getStandardListObjectInspector instead.
StandardConstantMapObjectInspector(ObjectInspector mapKeyObjectInspector, ObjectInspector mapValueObjectInspector, Map<?,?> value)
          Call ObjectInspectorFactory.getStandardMapObjectInspector instead.
StandardListObjectInspector(ObjectInspector listElementObjectInspector)
          Call ObjectInspectorFactory.getStandardListObjectInspector instead.
StandardMapObjectInspector(ObjectInspector mapKeyObjectInspector, ObjectInspector mapValueObjectInspector)
          Call ObjectInspectorFactory.getStandardMapObjectInspector instead.
StandardStructObjectInspector.MyField(int fieldID, String fieldName, ObjectInspector fieldObjectInspector)
           
StandardStructObjectInspector.MyField(int fieldID, String fieldName, ObjectInspector fieldObjectInspector, String fieldComment)
           
 

Constructor parameters in org.apache.hadoop.hive.serde2.objectinspector with type arguments of type ObjectInspector
StandardStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors)
          Call ObjectInspectorFactory.getStandardListObjectInspector instead.
StandardStructObjectInspector(List<String> structFieldNames, List<ObjectInspector> structFieldObjectInspectors, List<String> structFieldComments)
          Call ObjectInspectorFactory.getStandardListObjectInspector instead.
StandardUnionObjectInspector(List<ObjectInspector> ois)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.objectinspector.primitive
 

Subinterfaces of ObjectInspector in org.apache.hadoop.hive.serde2.objectinspector.primitive
 interface BinaryObjectInspector
           
 interface BooleanObjectInspector
          A BooleanObjectInspector inspects an Object representing a Boolean.
 interface ByteObjectInspector
          A ByteObjectInspector inspects an Object representing a Byte object.
 interface DateObjectInspector
          A DateObjectInspector inspects an Object representing a Date.
 interface DoubleObjectInspector
          A DoubleObjectInspector inspects an Object representing a Double.
 interface FloatObjectInspector
          A FloatObjectInspector inspects an Object representing a Float.
 interface HiveDecimalObjectInspector
          A DecimalObjectInspector inspects an Object representing a HiveDecimal.
 interface HiveVarcharObjectInspector
           
 interface IntObjectInspector
          A IntObjectInspector inspects an Object representing an Integer.
 interface LongObjectInspector
          A LongObjectInspector inspects an Object representing a Long.
 interface SettableBinaryObjectInspector
           
 interface SettableBooleanObjectInspector
          A SettableBooleanObjectInspector can set a boolean value to an object.
 interface SettableByteObjectInspector
          A SettableByteObjectInspector can set a byte value to an object.
 interface SettableDateObjectInspector
          A SettableDecimalObjectInspector can set a Date value to an object.
 interface SettableDoubleObjectInspector
          A SettableDoubleObjectInspector can set a double value to an object.
 interface SettableFloatObjectInspector
          A SettableFloatObjectInspector can set a float value to an object.
 interface SettableHiveDecimalObjectInspector
          A SettableDecimalObjectInspector can set a HiveDecimal value to an object.
 interface SettableHiveVarcharObjectInspector
           
 interface SettableIntObjectInspector
          A SettableIntObjectInspector can set an int value to an object.
 interface SettableLongObjectInspector
          A SettableLongObjectInspector can set a long value to an object.
 interface SettableShortObjectInspector
          A SettableShortObjectInspector can set a short value to an object.
 interface SettableStringObjectInspector
          A SettableStringObjectInspector can set a string value to an object.
 interface SettableTimestampObjectInspector
           
 interface ShortObjectInspector
          A ShortObjectInspector inspects an Object representing a Short.
 interface StringObjectInspector
          A StringObjectInspector inspects an Object representing a String.
 interface TimestampObjectInspector
           
 interface VoidObjectInspector
          A VoidObjectInspector can inspect a void object.
 

Classes in org.apache.hadoop.hive.serde2.objectinspector.primitive that implement ObjectInspector
 class AbstractPrimitiveJavaObjectInspector
          An AbstractJavaPrimitiveObjectInspector for a Java object.
 class AbstractPrimitiveObjectInspector
          An AbstractPrimitiveObjectInspector is based on ObjectInspectorUtils.PrimitiveTypeEntry.
 class AbstractPrimitiveWritableObjectInspector
          An AbstractWritablePrimitiveObjectInspector for a Writable object.
 class JavaBinaryObjectInspector
          Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
 class JavaBooleanObjectInspector
          A JavaBooleanObjectInspector inspects a Java Boolean Object.
 class JavaByteObjectInspector
          A JavaByteObjectInspector inspects a Java Byte Object.
 class JavaDateObjectInspector
          A JavaDateObjectInspector inspects a Java Date Object.
 class JavaDoubleObjectInspector
          A JavaDoubleObjectInspector inspects a Java Double Object.
 class JavaFloatObjectInspector
          A JavaFloatObjectInspector inspects a Java Float Object.
 class JavaHiveDecimalObjectInspector
           
 class JavaHiveVarcharObjectInspector
           
 class JavaIntObjectInspector
          A JavaIntObjectInspector inspects a Java Integer Object.
 class JavaLongObjectInspector
          A JavaLongObjectInspector inspects a Java Long Object.
 class JavaShortObjectInspector
          A JavaShortObjectInspector inspects a Java Short Object.
 class JavaStringObjectInspector
          A JavaStringObjectInspector inspects a Java String Object.
 class JavaTimestampObjectInspector
           
 class JavaVoidObjectInspector
          A JavaVoidObjectInspector inspects a Java Void Object.
 class WritableBinaryObjectInspector
          A WritableBinaryObjectInspector inspects a BytesWritable Object.
 class WritableBooleanObjectInspector
          A WritableBooleanObjectInspector inspects a BooleanWritable Object.
 class WritableByteObjectInspector
          A WritableByteObjectInspector inspects a ByteWritable Object.
 class WritableConstantBinaryObjectInspector
          A WritableConstantBinaryObjectInspector is a WritableBinaryObjectInspector that implements ConstantObjectInspector.
 class WritableConstantBooleanObjectInspector
          A WritableConstantBooleanObjectInspector is a WritableBooleanObjectInspector that implements ConstantObjectInspector.
 class WritableConstantByteObjectInspector
          A WritableConstantByteObjectInspector is a WritableByteObjectInspector that implements ConstantObjectInspector.
 class WritableConstantDateObjectInspector
          A WritableConstantDateObjectInspector is a WritableDateObjectInspector that implements ConstantObjectInspector.
 class WritableConstantDoubleObjectInspector
          A WritableConstantDoubleObjectInspector is a WritableDoubleObjectInspector that implements ConstantObjectInspector.
 class WritableConstantFloatObjectInspector
          A WritableConstantFloatObjectInspector is a WritableFloatObjectInspector that implements ConstantObjectInspector.
 class WritableConstantHiveDecimalObjectInspector
          A WritableConstantHiveDecimalObjectInspector is a WritableHiveDecimalObjectInspector that implements ConstantObjectInspector.
 class WritableConstantHiveVarcharObjectInspector
          A WritableConstantHiveVarcharObjectInspector is a WritableHiveVarcharObjectInspector that implements ConstantObjectInspector.
 class WritableConstantIntObjectInspector
          A WritableConstantIntObjectInspector is a WritableIntObjectInspector that implements ConstantObjectInspector.
 class WritableConstantLongObjectInspector
          A WritableConstantLongObjectInspector is a WritableLongObjectInspector that implements ConstantObjectInspector.
 class WritableConstantShortObjectInspector
          A WritableConstantShortObjectInspector is a WritableShortObjectInspector that implements ConstantObjectInspector.
 class WritableConstantStringObjectInspector
          A WritableConstantStringObjectInspector is a WritableStringObjectInspector that implements ConstantObjectInspector.
 class WritableConstantTimestampObjectInspector
          A WritableConstantTimestampObjectInspector is a WritableTimestampObjectInspector that implements ConstantObjectInspector.
 class WritableDateObjectInspector
          A WritableDateObjectInspector inspects a DateWritable Object.
 class WritableDoubleObjectInspector
          A WritableDoubleObjectInspector inspects a DoubleWritable Object.
 class WritableFloatObjectInspector
          A FloatObjectInspector inspects a FloatWritable Object.
 class WritableHiveDecimalObjectInspector
           
 class WritableHiveVarcharObjectInspector
           
 class WritableIntObjectInspector
          A WritableIntObjectInspector inspects a IntWritable Object.
 class WritableLongObjectInspector
          A WritableLongObjectInspector inspects a LongWritable Object.
 class WritableShortObjectInspector
          A WritableShortObjectInspector inspects a ShortWritable Object.
 class WritableStringObjectInspector
          A WritableStringObjectInspector inspects a Text Object.
 class WritableTimestampObjectInspector
           
 class WritableVoidObjectInspector
          A WritableVoidObjectInspector inspects a NullWritable Object.
 

Methods in org.apache.hadoop.hive.serde2.objectinspector.primitive with parameters of type ObjectInspector
static Class<?> PrimitiveObjectInspectorUtils.getJavaPrimitiveClassFromObjectInspector(ObjectInspector oi)
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.thrift
 

Methods in org.apache.hadoop.hive.serde2.thrift that return ObjectInspector
 ObjectInspector ThriftDeserializer.getObjectInspector()
           
 

Uses of ObjectInspector in org.apache.hadoop.hive.serde2.typeinfo
 

Methods in org.apache.hadoop.hive.serde2.typeinfo that return ObjectInspector
static ObjectInspector TypeInfoUtils.getStandardJavaObjectInspectorFromTypeInfo(TypeInfo typeInfo)
          Returns the standard object inspector that can be used to translate an object of that typeInfo to a standard object type.
static ObjectInspector TypeInfoUtils.getStandardWritableObjectInspectorFromTypeInfo(TypeInfo typeInfo)
          Returns the standard object inspector that can be used to translate an object of that typeInfo to a standard object type.
 

Methods in org.apache.hadoop.hive.serde2.typeinfo with parameters of type ObjectInspector
static TypeInfo TypeInfoUtils.getTypeInfoFromObjectInspector(ObjectInspector oi)
          Get the TypeInfo object from the ObjectInspector object by recursively going into the ObjectInspector structure.
 



Copyright © 2012 The Apache Software Foundation