Modifier and Type | Method and Description |
---|---|
StructObjectInspector |
GenericUDTFExplode2.initialize(ObjectInspector[] args) |
StructObjectInspector |
GenericUDTFCount2.initialize(ObjectInspector[] argOIs) |
Modifier and Type | Method and Description |
---|---|
StructObjectInspector |
PTFPartition.getInputOI() |
StructObjectInspector |
PTFPartition.getOutputOI() |
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.
|
static StructObjectInspector |
PTFPartition.setupPartitionOutputOI(SerDe serDe,
StructObjectInspector tblFnOI) |
Modifier and Type | Method and Description |
---|---|
static PTFPartition |
PTFPartition.create(org.apache.hadoop.conf.Configuration cfg,
SerDe serDe,
StructObjectInspector inputOI,
StructObjectInspector outputOI) |
static PTFRollingPartition |
PTFPartition.createRolling(org.apache.hadoop.conf.Configuration cfg,
SerDe serDe,
StructObjectInspector inputOI,
StructObjectInspector outputOI,
int precedingSpan,
int followingSpan) |
static StructObjectInspector |
PTFPartition.setupPartitionOutputOI(SerDe serDe,
StructObjectInspector tblFnOI) |
Constructor and Description |
---|
PTFPartition(org.apache.hadoop.conf.Configuration cfg,
SerDe serDe,
StructObjectInspector inputOI,
StructObjectInspector outputOI) |
PTFPartition(org.apache.hadoop.conf.Configuration cfg,
SerDe serDe,
StructObjectInspector inputOI,
StructObjectInspector outputOI,
boolean createElemContainer) |
PTFRollingPartition(org.apache.hadoop.conf.Configuration cfg,
SerDe serDe,
StructObjectInspector inputOI,
StructObjectInspector outputOI,
int precedingSpan,
int succeedingSpan) |
Modifier and Type | Method and Description |
---|---|
static TableDesc |
PTFRowContainer.createTableDesc(StructObjectInspector oI) |
Modifier and Type | Method and Description |
---|---|
static void |
VectorizedBatchUtil.acidAddRowToBatch(Object row,
StructObjectInspector oi,
int rowIndex,
VectorizedRowBatch batch,
VectorizedRowBatchCtx context,
org.apache.hadoop.io.DataOutputBuffer buffer)
Iterates thru all the columns in a given row and populates the batch
from a given offset
|
static void |
VectorizedBatchUtil.addProjectedRowToBatchFrom(Object row,
StructObjectInspector oi,
int rowIndex,
VectorizedRowBatch batch,
org.apache.hadoop.io.DataOutputBuffer buffer)
Add only the projected column of a regular row to the specified vectorized row batch
|
static void |
VectorizedBatchUtil.addRowToBatch(Object row,
StructObjectInspector oi,
int rowIndex,
VectorizedRowBatch batch,
org.apache.hadoop.io.DataOutputBuffer buffer)
Iterates through all columns in a given row and populates the batch
|
static void |
VectorizedBatchUtil.addRowToBatchFrom(Object row,
StructObjectInspector oi,
int rowIndex,
int colOffset,
VectorizedRowBatch batch,
org.apache.hadoop.io.DataOutputBuffer buffer)
Iterates thru all the columns in a given row and populates the batch
from a given offset
|
static VectorizedRowBatch |
VectorizedBatchUtil.constructVectorizedRowBatch(StructObjectInspector oi)
Create VectorizedRowBatch from ObjectInspector
|
static VectorizedRowBatch |
VectorizedBatchUtil.constructVectorizedRowBatch(StructObjectInspector keyInspector,
StructObjectInspector valueInspector)
Create VectorizedRowBatch from key and value object inspectors
|
static StandardStructObjectInspector |
VectorizedBatchUtil.convertToStandardStructObjectInspector(StructObjectInspector structObjectInspector) |
void |
VectorizedRowBatchCtx.init(Map<Integer,String> scratchColumnTypeMap,
StructObjectInspector rowOI)
Initializes the VectorizedRowBatch context based on an scratch column type map and
object inspector.
|
void |
VectorExtractRow.init(StructObjectInspector structObjectInspector,
List<Integer> projectedColumns) |
void |
VectorAssignRow.init(StructObjectInspector structObjectInspector,
List<Integer> projectedColumns) |
static PrimitiveTypeInfo[] |
VectorizedBatchUtil.primitiveTypeInfosFromStructObjectInspector(StructObjectInspector structObjectInspector) |
Constructor and Description |
---|
VectorizedRowBatchCtx(StructObjectInspector rawRowOI,
StructObjectInspector rowOI,
Deserializer deserializer,
Map<String,Object> partitionValues,
Map<String,PrimitiveObjectInspector.PrimitiveCategory> partitionTypes)
Constructor for VectorizedRowBatchCtx
|
Modifier and Type | Method and Description |
---|---|
static VectorExpressionWriter[] |
VectorExpressionWriterFactory.genVectorStructExpressionWritables(StructObjectInspector oi)
Compiles the appropriate vector expression writers based on a struct object
inspector.
|
static VectorExpressionWriter[] |
VectorExpressionWriterFactory.getExpressionWriters(StructObjectInspector objInspector)
Returns
VectorExpressionWriter objects for the fields in the given
object inspector. |
static void |
VectorExpressionWriterFactory.processVectorInspector(StructObjectInspector structObjInspector,
VectorExpressionWriterFactory.SingleOIDClosure closure)
Creates the value writers for an struct object inspector.
|
Modifier and Type | Class and Description |
---|---|
class |
ArrayWritableObjectInspector
The ArrayWritableObjectInspector will inspect an ArrayWritable, considering it as a Hive struct.
It can also inspect a List if Hive decides to inspect the result of an inspection. |
Modifier and Type | Method and Description |
---|---|
static StructObjectInspector |
VirtualColumn.getVCSObjectInspector(List<VirtualColumn> vcs) |
Modifier and Type | Method and Description |
---|---|
static Object |
PartExprEvalUtils.evalExprWithPart(ExprNodeDesc expr,
Partition p,
List<VirtualColumn> vcs,
StructObjectInspector rowObjectInspector)
Evaluate expression with partition columns
|
Modifier and Type | Method and Description |
---|---|
static StructObjectInspector |
PTFTranslator.getStandardStructOI(RowResolver rr)
For each column on the input RR, construct a StructField for it
OI is constructed using the list of input column names and
their corresponding OIs.
|
Modifier and Type | Method and Description |
---|---|
protected static RowResolver |
PTFTranslator.buildRowResolverForNoop(String tabAlias,
StructObjectInspector rowObjectInspector,
RowResolver inputRowResolver) |
protected static RowResolver |
PTFTranslator.buildRowResolverForPTF(String tbFnName,
String tabAlias,
StructObjectInspector rowObjectInspector,
List<String> outputColNames,
RowResolver inputRR) |
protected static SerDe |
PTFTranslator.createLazyBinarySerDe(org.apache.hadoop.conf.Configuration cfg,
StructObjectInspector oi,
Map<String,String> serdePropsMap) |
Modifier and Type | Method and Description |
---|---|
StructObjectInspector |
FetchWork.getStatRowOI() |
Modifier and Type | Method and Description |
---|---|
static void |
PTFDeserializer.addOIPropertiestoSerDePropsMap(StructObjectInspector OI,
Map<String,String> serdePropsMap) |
protected void |
PTFDeserializer.initialize(PTFQueryInputDef def,
StructObjectInspector OI) |
protected void |
PTFDeserializer.initialize(ShapeDetails shp,
StructObjectInspector OI) |
Constructor and Description |
---|
FetchWork(List<List<Object>> rowsComputedFromStats,
StructObjectInspector statRowOI) |
PTFDeserializer(PTFDesc ptfDesc,
StructObjectInspector inputOI,
org.apache.hadoop.conf.Configuration hConf) |
Modifier and Type | Method and Description |
---|---|
StructObjectInspector |
ShapeDetails.getOI() |
Modifier and Type | Method and Description |
---|---|
void |
ShapeDetails.setOI(StructObjectInspector oI) |
Modifier and Type | Field and Description |
---|---|
protected StructObjectInspector |
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.soi |
Modifier and Type | Method and Description |
---|---|
StructObjectInspector |
GenericUDTFStack.initialize(ObjectInspector[] args) |
StructObjectInspector |
GenericUDTFPosExplode.initialize(ObjectInspector[] args) |
StructObjectInspector |
GenericUDTFParseUrlTuple.initialize(ObjectInspector[] args) |
StructObjectInspector |
GenericUDTFJSONTuple.initialize(ObjectInspector[] args) |
StructObjectInspector |
GenericUDTFInline.initialize(ObjectInspector[] ois) |
StructObjectInspector |
GenericUDTFExplode.initialize(ObjectInspector[] args) |
StructObjectInspector |
GenericUDTF.initialize(ObjectInspector[] argOIs)
Deprecated.
|
StructObjectInspector |
GenericUDTF.initialize(StructObjectInspector argOIs) |
Modifier and Type | Method and Description |
---|---|
StructObjectInspector |
GenericUDTF.initialize(StructObjectInspector argOIs) |
Modifier and Type | Field and Description |
---|---|
protected StructObjectInspector |
TableFunctionEvaluator.OI |
protected StructObjectInspector |
TableFunctionEvaluator.rawInputOI |
Modifier and Type | Method and Description |
---|---|
protected static StructObjectInspector |
MatchPath.createSelectListOI(MatchPath evaluator,
PTFInputDef inpDef) |
StructObjectInspector |
TableFunctionEvaluator.getOutputOI() |
StructObjectInspector |
TableFunctionEvaluator.getRawInputOI() |
StructObjectInspector |
WindowingTableFunction.WindowingTableFunctionResolver.getWdwProcessingOutputOI() |
Modifier and Type | Method and Description |
---|---|
void |
WindowingTableFunction.initializeStreaming(org.apache.hadoop.conf.Configuration cfg,
StructObjectInspector inputOI,
boolean isMapSide) |
void |
TableFunctionEvaluator.initializeStreaming(org.apache.hadoop.conf.Configuration cfg,
StructObjectInspector inputOI,
boolean isMapSide) |
void |
NoopWithMapStreaming.initializeStreaming(org.apache.hadoop.conf.Configuration cfg,
StructObjectInspector inputOI,
boolean isMapSide) |
void |
NoopStreaming.initializeStreaming(org.apache.hadoop.conf.Configuration cfg,
StructObjectInspector inputOI,
boolean isMapSide) |
protected void |
WindowingTableFunction.setOutputOI(StructObjectInspector outputOI) |
protected void |
TableFunctionResolver.setOutputOI(StructObjectInspector outputOI) |
protected void |
TableFunctionEvaluator.setOutputOI(StructObjectInspector outputOI) |
protected void |
TableFunctionResolver.setRawInputOI(StructObjectInspector rawInputOI) |
protected void |
TableFunctionEvaluator.setRawInputOI(StructObjectInspector rawInputOI) |
void |
WindowingTableFunction.WindowingTableFunctionResolver.setWdwProcessingOutputOI(StructObjectInspector wdwProcessingOutputOI) |
Modifier and Type | Class and Description |
---|---|
class |
BaseStructObjectInspector |
static class |
NullStructSerDe.NullStructSerDeObjectInspector
A object inspector for null struct serde.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
SerDeUtils.hasAnyNullObject(List o,
StructObjectInspector loi,
boolean[] nullSafes)
return false though element is null if nullsafe flag is true for that
|
Modifier and Type | Class and Description |
---|---|
class |
AvroLazyObjectInspector
Lazy objectinspector for avro serialization
|
Modifier and Type | Field and Description |
---|---|
StructObjectInspector |
ParquetHiveRecord.inspector |
Modifier and Type | Method and Description |
---|---|
StructObjectInspector |
ParquetHiveRecord.getObjectInspector() |
Constructor and Description |
---|
ParquetHiveRecord(Object o,
StructObjectInspector oi) |
Modifier and Type | Class and Description |
---|---|
class |
LazySimpleStructObjectInspector
LazySimpleStructObjectInspector works on struct data that is stored in
LazyStruct.
|
Modifier and Type | Class and Description |
---|---|
class |
LazyBinaryStructObjectInspector
ObjectInspector for LazyBinaryStruct.
|
Modifier and Type | Class and Description |
---|---|
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 |
StandardStructObjectInspector
ListStructObjectInspector works on struct data that is stored as a Java List
or Java Array object.
|
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 |
ThriftUnionObjectInspector
Always use the ObjectInspectorFactory to create new ObjectInspector objects,
instead of directly creating an instance of this class.
|
class |
UnionStructObjectInspector
UnionStructObjectInspector unions several struct data into a single struct.
|
Modifier and Type | Field and Description |
---|---|
protected StructObjectInspector |
SubStructObjectInspector.baseOI |
Modifier and Type | Method and Description |
---|---|
static void |
ObjectInspectorUtils.copyToStandardObject(List<Object> result,
Object row,
StructObjectInspector soi,
ObjectInspectorUtils.ObjectInspectorCopyOption objectInspectorOption)
Copy fields in the input row to the output array of standard objects.
|
static String |
ObjectInspectorUtils.getFieldNames(StructObjectInspector soi)
Get the list of field names as csv from a StructObjectInspector.
|
static String |
ObjectInspectorUtils.getFieldTypes(StructObjectInspector soi)
Get the list of field type as csv from a StructObjectInspector.
|
static String |
ObjectInspectorUtils.getStandardStructTypeName(StructObjectInspector soi) |
static void |
ObjectInspectorUtils.partialCopyToStandardObject(List<Object> result,
Object row,
int startCol,
int numCols,
StructObjectInspector soi,
ObjectInspectorUtils.ObjectInspectorCopyOption objectInspectorOption)
Copy specified fields in the input row to the output array of standard objects.
|
Modifier and Type | Method and Description |
---|---|
static UnionStructObjectInspector |
ObjectInspectorFactory.getUnionStructObjectInspector(List<StructObjectInspector> structObjectInspectors) |
Constructor and Description |
---|
SubStructObjectInspector(StructObjectInspector baseOI,
int startCol,
int numCols)
Create a new Object Inspector based on a base object inspector and the subset of
columns will be inspected (from startCol to startCol+numCols).
|
Constructor and Description |
---|
UnionStructObjectInspector(List<StructObjectInspector> unionObjectInspectors) |
Modifier and Type | Class and Description |
---|---|
class |
HCatRecordObjectInspector |
Copyright © 2017 The Apache Software Foundation. All rights reserved.