|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
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 |
CollectOperator.standardRowInspector
|
Fields in org.apache.hadoop.hive.ql.exec with type parameters of type ObjectInspector | |
---|---|
protected Map<Byte,List<ObjectInspector>> |
MapJoinOperator.joinKeysObjectInspectors
The ObjectInspectors for the join inputs's join keys. |
protected Map<Byte,List<ObjectInspector>> |
MapJoinOperator.joinKeysStandardObjectInspectors
The standard ObjectInspectors for the join inputs's join keys. |
protected Map<Byte,List<ObjectInspector>> |
CommonJoinOperator.joinValuesObjectInspectors
The ObjectInspectors for the join inputs. |
protected Map<Byte,List<ObjectInspector>> |
CommonJoinOperator.joinValuesStandardObjectInspectors
The standard ObjectInspectors for the join inputs. |
protected ArrayList<ObjectInspector> |
GroupByOperator.objectInspectors
|
Methods in org.apache.hadoop.hive.ql.exec that return ObjectInspector | ||
---|---|---|
protected static
|
CommonJoinOperator.getJoinOutputObjectInspector(Byte[] order,
Map<Byte,List<ObjectInspector>> aliasToObjectInspectors,
T conf)
|
|
ObjectInspector |
FetchOperator.getOutputObjectInspector()
|
|
ObjectInspector |
MapJoinOperator.MapJoinObjectCtx.getStandardOI()
|
|
protected static ObjectInspector[] |
Operator.initEvaluators(ExprNodeEvaluator[] evals,
ObjectInspector rowInspector)
Initialize an array of ExprNodeEvaluator and return the result ObjectInspectors. |
|
ObjectInspector |
ExprNodeNullEvaluator.initialize(ObjectInspector rowInspector)
|
|
ObjectInspector |
ExprNodeGenericFuncEvaluator.initialize(ObjectInspector rowInspector)
|
|
ObjectInspector |
ExprNodeFuncEvaluator.initialize(ObjectInspector rowInspector)
|
|
ObjectInspector |
ExprNodeFieldEvaluator.initialize(ObjectInspector rowInspector)
|
|
ObjectInspector |
ExprNodeConstantEvaluator.initialize(ObjectInspector rowInspector)
|
|
ObjectInspector |
ExprNodeColumnEvaluator.initialize(ObjectInspector rowInspector)
|
|
abstract ObjectInspector |
ExprNodeEvaluator.initialize(ObjectInspector rowInspector)
Initialize should be called once and only once. |
Methods in org.apache.hadoop.hive.ql.exec that return types with arguments of type ObjectInspector | |
---|---|
protected static HashMap<Byte,List<ObjectInspector>> |
CommonJoinOperator.getObjectInspectorsFromEvaluators(Map<Byte,List<ExprNodeEvaluator>> exprEntries,
ObjectInspector[] inputObjInspector)
|
protected static HashMap<Byte,List<ObjectInspector>> |
CommonJoinOperator.getStandardObjectInspectors(Map<Byte,List<ObjectInspector>> aliasToObjectInspectors)
|
Methods in org.apache.hadoop.hive.ql.exec with parameters of type ObjectInspector | |
---|---|
protected void |
Operator.forward(Object row,
ObjectInspector rowInspector)
|
protected static HashMap<Byte,List<ObjectInspector>> |
CommonJoinOperator.getObjectInspectorsFromEvaluators(Map<Byte,List<ExprNodeEvaluator>> exprEntries,
ObjectInspector[] inputObjInspector)
|
protected static ObjectInspector[] |
Operator.initEvaluators(ExprNodeEvaluator[] evals,
ObjectInspector rowInspector)
Initialize an array of ExprNodeEvaluator and return the result ObjectInspectors. |
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(org.apache.hadoop.conf.Configuration hconf,
ObjectInspector[] inputOIs)
Initializes operators only if all parents have been initialized. |
ObjectInspector |
ExprNodeNullEvaluator.initialize(ObjectInspector rowInspector)
|
ObjectInspector |
ExprNodeGenericFuncEvaluator.initialize(ObjectInspector rowInspector)
|
ObjectInspector |
ExprNodeFuncEvaluator.initialize(ObjectInspector rowInspector)
|
ObjectInspector |
ExprNodeFieldEvaluator.initialize(ObjectInspector rowInspector)
|
ObjectInspector |
ExprNodeConstantEvaluator.initialize(ObjectInspector rowInspector)
|
ObjectInspector |
ExprNodeColumnEvaluator.initialize(ObjectInspector rowInspector)
|
abstract ObjectInspector |
ExprNodeEvaluator.initialize(ObjectInspector rowInspector)
Initialize should be called once and only once. |
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 | ||
---|---|---|
protected static ArrayList<Object> |
CommonJoinOperator.computeValues(Object row,
List<ExprNodeEvaluator> valueFields,
List<ObjectInspector> valueFieldsOI)
Return the value as a standard object. |
|
protected static
|
CommonJoinOperator.getJoinOutputObjectInspector(Byte[] order,
Map<Byte,List<ObjectInspector>> aliasToObjectInspectors,
T conf)
|
|
protected static HashMap<Byte,List<ObjectInspector>> |
CommonJoinOperator.getStandardObjectInspectors(Map<Byte,List<ObjectInspector>> aliasToObjectInspectors)
|
Constructors in org.apache.hadoop.hive.ql.exec with parameters of type ObjectInspector | |
---|---|
MapJoinOperator.MapJoinObjectCtx(ObjectInspector standardOI,
SerDe serde)
|
Uses of ObjectInspector in org.apache.hadoop.hive.ql.udf.generic |
---|
Methods in org.apache.hadoop.hive.ql.udf.generic that return ObjectInspector | |
---|---|
ObjectInspector |
GenericUDFUtils.ReturnObjectInspectorResolver.get()
Returns the ObjectInspector of the return value. |
ObjectInspector |
GenericUDAFSum.GenericUDAFSumDouble.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
|
ObjectInspector |
GenericUDAFSum.GenericUDAFSumLong.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
|
ObjectInspector |
GenericUDAFVariance.GenericUDAFVarianceEvaluator.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 |
GenericUDAFAverage.GenericUDAFAverageEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
|
ObjectInspector |
GenericUDAFEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
Initialize the evaluator. |
ObjectInspector |
GenericUDFWhen.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFSplit.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFSize.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFOPNull.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFOPNotNull.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFLocate.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFInstr.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFIndex.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFIf.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFHash.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFElt.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFCoalesce.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFCase.initialize(ObjectInspector[] arguments)
|
abstract ObjectInspector |
GenericUDF.initialize(ObjectInspector[] arguments)
Initialize this GenericUDF. |
Methods in org.apache.hadoop.hive.ql.udf.generic with parameters of type ObjectInspector | |
---|---|
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). |
ObjectInspector |
GenericUDAFSum.GenericUDAFSumDouble.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
|
ObjectInspector |
GenericUDAFSum.GenericUDAFSumLong.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
|
ObjectInspector |
GenericUDAFVariance.GenericUDAFVarianceEvaluator.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 |
GenericUDAFAverage.GenericUDAFAverageEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
|
ObjectInspector |
GenericUDAFEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
Initialize the evaluator. |
ObjectInspector |
GenericUDFWhen.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFSplit.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFSize.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFOPNull.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFOPNotNull.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFLocate.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFInstr.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFIndex.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFIf.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFHash.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFElt.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFCoalesce.initialize(ObjectInspector[] arguments)
|
ObjectInspector |
GenericUDFCase.initialize(ObjectInspector[] arguments)
|
abstract ObjectInspector |
GenericUDF.initialize(ObjectInspector[] arguments)
Initialize this GenericUDF. |
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.PrimitiveConversionHelper(Method m,
ObjectInspector[] parameters)
Create a PrimitiveConversionHelper for Method m. |
Uses of ObjectInspector in org.apache.hadoop.hive.serde2 |
---|
Methods in org.apache.hadoop.hive.serde2 that return ObjectInspector | |
---|---|
ObjectInspector |
MetadataTypedColumnsetSerDe.getObjectInspector()
|
ObjectInspector |
Deserializer.getObjectInspector()
Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...). |
ObjectInspector |
TypedSerDe.getObjectInspector()
|
Methods in org.apache.hadoop.hive.serde2 with parameters of type ObjectInspector | |
---|---|
static String |
SerDeUtils.getJSONString(Object o,
ObjectInspector oi)
|
org.apache.hadoop.io.Writable |
MetadataTypedColumnsetSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
org.apache.hadoop.io.Writable |
Serializer.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object by navigating inside the Object with the ObjectInspector. |
org.apache.hadoop.io.Writable |
TypedSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
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 | |
---|---|
org.apache.hadoop.io.Writable |
BinarySortableSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
Uses of ObjectInspector in org.apache.hadoop.hive.serde2.columnar |
---|
Methods in org.apache.hadoop.hive.serde2.columnar that return ObjectInspector | |
---|---|
ObjectInspector |
ColumnarSerDe.getObjectInspector()
Returns the ObjectInspector for the row. |
Methods in org.apache.hadoop.hive.serde2.columnar with parameters of type ObjectInspector | |
---|---|
org.apache.hadoop.io.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. |
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 | |
---|---|
org.apache.hadoop.io.Writable |
DynamicSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
void |
DynamicSerDeTypeList.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
void |
DynamicSerDeTypeSet.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 |
DynamicSerDeTypeBool.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 |
DynamicSerDeTypei64.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 |
DynamicSerDeTypei16.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 |
DynamicSerDeTypeString.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
void |
DynamicSerDeTypedef.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
void |
DynamicSerDeFieldList.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 |
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. |
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. |
Methods in org.apache.hadoop.hive.serde2.lazy that return ObjectInspector | |
---|---|
static ObjectInspector |
LazyFactory.createColumnarStructInspector(List<String> columnNames,
List<TypeInfo> columnTypes,
byte[] separators,
org.apache.hadoop.io.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,
org.apache.hadoop.io.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,
org.apache.hadoop.io.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 with parameters of type ObjectInspector | |
---|---|
static LazyObject |
LazyFactory.createLazyObject(ObjectInspector oi)
Create a hierarchical LazyObject based on the given typeInfo. |
static void |
LazySimpleSerDe.serialize(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
byte[] separators,
int level,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar,
boolean[] needsEscape)
Serialize the row into the StringBuilder. |
org.apache.hadoop.io.Writable |
LazySimpleSerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize a row of data. |
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. |
Fields in org.apache.hadoop.hive.serde2.lazy.objectinspector declared as ObjectInspector | |
---|---|
protected ObjectInspector |
LazySimpleStructObjectInspector.MyField.fieldObjectInspector
|
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 with parameters of type ObjectInspector | |
---|---|
static LazyListObjectInspector |
LazyObjectInspectorFactory.getLazySimpleListObjectInspector(ObjectInspector listElementObjectInspector,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
|
static LazyMapObjectInspector |
LazyObjectInspectorFactory.getLazySimpleMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector,
byte itemSeparator,
byte keyValueSeparator,
org.apache.hadoop.io.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,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar)
|
protected void |
LazySimpleStructObjectInspector.init(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
byte separator,
org.apache.hadoop.io.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,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Call ObjectInspectorFactory.getLazySimpleListObjectInspector instead. |
|
LazyMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector,
byte itemSeparator,
byte keyValueSeparator,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Call ObjectInspectorFactory.getStandardListObjectInspector instead. |
|
LazySimpleStructObjectInspector.MyField(int fieldID,
String fieldName,
ObjectInspector fieldObjectInspector)
|
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,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar)
Call ObjectInspectorFactory.getLazySimpleStructObjectInspector instead. |
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 |
LazyBooleanObjectInspector
A WritableBooleanObjectInspector inspects a BooleanWritable Object. |
class |
LazyByteObjectInspector
A WritableByteObjectInspector inspects a ByteWritable Object. |
class |
LazyDoubleObjectInspector
A WritableDoubleObjectInspector inspects a DoubleWritable Object. |
class |
LazyFloatObjectInspector
A FloatObjectInspector inspects a FloatWritable Object. |
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 |
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>
|
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 |
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. |
org.apache.hadoop.io.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)
|
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)
|
Uses of ObjectInspector in org.apache.hadoop.hive.serde2.objectinspector |
---|
Subinterfaces of ObjectInspector in org.apache.hadoop.hive.serde2.objectinspector | |
---|---|
interface |
ListObjectInspector
|
interface |
MapObjectInspector
|
interface |
PrimitiveObjectInspector
|
Classes in org.apache.hadoop.hive.serde2.objectinspector that implement ObjectInspector | |
---|---|
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 |
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 |
StructObjectInspector
|
class |
UnionStructObjectInspector
UnionStructObjectInspector unions several struct data into a single struct. |
Fields in org.apache.hadoop.hive.serde2.objectinspector declared as ObjectInspector | |
---|---|
protected ObjectInspector |
StandardStructObjectInspector.MyField.fieldObjectInspector
|
protected ObjectInspector |
ReflectionStructObjectInspector.MyField.fieldObjectInspector
|
ObjectInspector |
InspectableObject.oi
|
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 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 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 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 int |
ObjectInspectorUtils.hashCode(Object o,
ObjectInspector objIns)
|
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,
org.apache.hadoop.io.Text nullSequence)
|
static StandardStructObjectInspector |
ObjectInspectorFactory.getStandardStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors)
|
protected void |
StandardStructObjectInspector.init(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors)
|
Constructors in org.apache.hadoop.hive.serde2.objectinspector with parameters of type ObjectInspector | |
---|---|
InspectableObject(Object o,
ObjectInspector oi)
|
|
ReflectionStructObjectInspector.MyField(Field field,
ObjectInspector fieldObjectInspector)
|
|
StandardListObjectInspector(ObjectInspector listElementObjectInspector)
Call ObjectInspectorFactory.getStandardListObjectInspector instead. |
|
StandardMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector)
Call ObjectInspectorFactory.getStandardMapObjectInspector instead. |
|
StandardStructObjectInspector.MyField(int fieldID,
String fieldName,
ObjectInspector fieldObjectInspector)
|
Constructor parameters in org.apache.hadoop.hive.serde2.objectinspector with type arguments of type ObjectInspector | |
---|---|
ReflectionStructObjectInspector(Class<?> objectClass,
List<ObjectInspector> structFieldObjectInspectors)
|
|
StandardStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors)
Call ObjectInspectorFactory.getStandardListObjectInspector instead. |
Uses of ObjectInspector in org.apache.hadoop.hive.serde2.objectinspector.primitive |
---|
Subinterfaces of ObjectInspector in org.apache.hadoop.hive.serde2.objectinspector.primitive | |
---|---|
interface |
BooleanObjectInspector
A BooleanObjectInspector inspects an Object representing a Boolean. |
interface |
ByteObjectInspector
A ByteObjectInspector inspects an Object representing a Byte object. |
interface |
DoubleObjectInspector
A DoubleObjectInspector inspects an Object representing a Double. |
interface |
FloatObjectInspector
A FloatObjectInspector inspects an Object representing a Float. |
interface |
IntObjectInspector
A IntObjectInspector inspects an Object representing an Integer. |
interface |
LongObjectInspector
A LongObjectInspector inspects an Object representing a Long. |
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 |
SettableDoubleObjectInspector
A SettableDoubleObjectInspector can set a double value to an object. |
interface |
SettableFloatObjectInspector
A SettableFloatObjectInspector can set a float value to an object. |
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 |
ShortObjectInspector
A ShortObjectInspector inspects an Object representing a Short. |
interface |
StringObjectInspector
A StringObjectInspector inspects an Object representing a String. |
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 |
JavaBooleanObjectInspector
A JavaBooleanObjectInspector inspects a Java Boolean Object. |
class |
JavaByteObjectInspector
A JavaByteObjectInspector inspects a Java Byte Object. |
class |
JavaDoubleObjectInspector
A JavaDoubleObjectInspector inspects a Java Double Object. |
class |
JavaFloatObjectInspector
A JavaFloatObjectInspector inspects a Java Float Object. |
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 |
JavaVoidObjectInspector
A JavaVoidObjectInspector inspects a Java Void Object. |
class |
WritableBooleanObjectInspector
A WritableBooleanObjectInspector inspects a BooleanWritable Object. |
class |
WritableByteObjectInspector
A WritableByteObjectInspector inspects a ByteWritable Object. |
class |
WritableDoubleObjectInspector
A WritableDoubleObjectInspector inspects a DoubleWritable Object. |
class |
WritableFloatObjectInspector
A FloatObjectInspector inspects a FloatWritable Object. |
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 |
WritableVoidObjectInspector
A WritableVoidObjectInspector inspects a NullWritable Object. |
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. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |