Modifier and Type | Method and Description |
---|---|
ObjectInspector |
DefaultAccumuloRowIdFactory.createRowIdObjectInspector(TypeInfo type) |
ObjectInspector |
AccumuloRowIdFactory.createRowIdObjectInspector(TypeInfo type)
create custom object inspector for accumulo rowId
|
ObjectInspector |
AccumuloSerDe.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
protected ArrayList<ObjectInspector> |
AccumuloSerDe.getColumnObjectInspectors(List<TypeInfo> columnTypes,
LazySerDeParameters serDeParams,
List<ColumnMapping> mappings,
AccumuloRowIdFactory factory) |
LazyObject<? extends ObjectInspector> |
AccumuloCompositeRowId.toLazyObject(int fieldID,
byte[] bytes)
Create an initialize a
LazyObject with the given bytes for the given fieldID. |
Modifier and Type | Method and Description |
---|---|
LazyObjectBase |
DefaultAccumuloRowIdFactory.createRowId(ObjectInspector inspector) |
T |
CompositeAccumuloRowIdFactory.createRowId(ObjectInspector inspector) |
LazyObjectBase |
AccumuloRowIdFactory.createRowId(ObjectInspector inspector)
create custom object for accumulo
|
protected byte[] |
AccumuloRowSerializer.getSerializedValue(ObjectInspector fieldObjectInspector,
Object value,
ByteStream.Output output,
ColumnMapping mapping)
Compute the serialized value from the given element and object inspectors.
|
org.apache.hadoop.io.Writable |
AccumuloSerDe.serialize(Object o,
ObjectInspector objectInspector) |
org.apache.accumulo.core.data.Mutation |
AccumuloRowSerializer.serialize(Object obj,
ObjectInspector objInspector) |
protected void |
AccumuloRowSerializer.serializeColumnMapping(HiveAccumuloColumnMapping columnMapping,
ObjectInspector fieldObjectInspector,
Object value,
org.apache.accumulo.core.data.Mutation mutation) |
protected void |
AccumuloRowSerializer.serializeColumnMapping(HiveAccumuloMapColumnMapping columnMapping,
ObjectInspector fieldObjectInspector,
Object value,
org.apache.accumulo.core.data.Mutation mutation)
Serialize the Hive Map into an Accumulo row
|
protected void |
AccumuloRowSerializer.writeWithLevel(ObjectInspector oi,
Object value,
ByteStream.Output output,
ColumnMapping mapping,
int level)
Recursively serialize an Object using its
ObjectInspector , respecting the
separators defined by the LazySerDeParameters . |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
GenericUDFDBOutput.initialize(ObjectInspector[] arguments) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
GenericUDFDBOutput.initialize(ObjectInspector[] arguments) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
TypedBytesSerDe.getObjectInspector() |
ObjectInspector |
RegexSerDe.getObjectInspector() |
ObjectInspector |
MultiDelimitSerDe.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.io.Writable |
TypedBytesSerDe.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
RegexSerDe.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
MultiDelimitSerDe.serialize(Object obj,
ObjectInspector objInspector) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
S3LogDeserializer.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
StructObjectInspector |
GenericUDTFExplode2.initialize(ObjectInspector[] args) |
StructObjectInspector |
GenericUDTFCount2.initialize(ObjectInspector[] argOIs) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
HBaseKeyFactory.createKeyObjectInspector(TypeInfo type)
create custom object inspector for hbase key
|
ObjectInspector |
DefaultHBaseKeyFactory.createKeyObjectInspector(TypeInfo type) |
static ObjectInspector |
HBaseLazyObjectFactory.createLazyHBaseStructInspector(LazySerDeParameters serdeParams,
int index,
HBaseKeyFactory keyFactory,
List<HBaseValueFactory> valueFactories) |
ObjectInspector |
HBaseSerDe.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
LazyObject<? extends ObjectInspector> |
HBaseCompositeKey.toLazyObject(int fieldID,
byte[] bytes)
Create an initialize a
LazyObject with the given bytes for the given fieldID. |
Modifier and Type | Method and Description |
---|---|
LazyObjectBase |
HBaseKeyFactory.createKey(ObjectInspector inspector)
create custom object for hbase key
|
LazyObjectBase |
DefaultHBaseKeyFactory.createKey(ObjectInspector inspector) |
T |
CompositeHBaseKeyFactory.createKey(ObjectInspector inspector) |
static LazyObjectBase |
HBaseSerDeHelper.createLazyField(ColumnMappings.ColumnMapping[] columnMappings,
int fieldID,
ObjectInspector inspector)
Create the
lazy field |
org.apache.hadoop.io.Writable |
HBaseSerDe.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
HBaseRowSerializer.serialize(Object obj,
ObjectInspector objInspector) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
HBaseValueFactory.createValueObjectInspector(TypeInfo type)
create custom object inspector for the value
|
ObjectInspector |
DefaultHBaseValueFactory.createValueObjectInspector(TypeInfo type) |
ObjectInspector |
AvroHBaseValueFactory.createValueObjectInspector(TypeInfo type) |
Modifier and Type | Method and Description |
---|---|
LazyObject<? extends ObjectInspector> |
HBaseStructValue.toLazyObject(int fieldID,
byte[] bytes)
Create an initialize a
LazyObject with the given bytes for the given fieldID. |
Modifier and Type | Method and Description |
---|---|
LazyObjectBase |
StructHBaseValueFactory.createValueObject(ObjectInspector inspector) |
LazyObjectBase |
HBaseValueFactory.createValueObject(ObjectInspector inspector)
create custom object for hbase value
|
LazyObjectBase |
DefaultHBaseValueFactory.createValueObject(ObjectInspector inspector) |
Modifier and Type | Field and Description |
---|---|
protected ObjectInspector[] |
Operator.inputObjInspectors |
protected ObjectInspector |
ReduceSinkOperator.keyObjectInspector |
protected ObjectInspector |
Operator.outputObjInspector |
protected ObjectInspector |
ExprNodeEvaluator.outputOI |
protected ObjectInspector |
CollectOperator.standardRowInspector |
protected ObjectInspector |
ReduceSinkOperator.valueObjectInspector |
Modifier and Type | Method and Description |
---|---|
ObjectInspector[] |
Operator.getInputObjInspectors() |
ObjectInspector |
ColumnInfo.getObjectInspector() |
ObjectInspector |
FetchOperator.getOutputObjectInspector()
returns output ObjectInspector, never null
|
ObjectInspector |
Operator.getOutputObjInspector() |
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 |
ExprNodeGenericFuncEvaluator.initialize(ObjectInspector rowInspector) |
ObjectInspector |
ExprNodeFieldEvaluator.initialize(ObjectInspector rowInspector) |
ObjectInspector |
ExprNodeEvaluatorRef.initialize(ObjectInspector rowInspector) |
ObjectInspector |
ExprNodeEvaluatorHead.initialize(ObjectInspector rowInspector) |
abstract ObjectInspector |
ExprNodeEvaluator.initialize(ObjectInspector rowInspector)
Initialize should be called once and only once.
|
ObjectInspector |
ExprNodeConstantEvaluator.initialize(ObjectInspector rowInspector) |
ObjectInspector |
ExprNodeColumnEvaluator.initialize(ObjectInspector rowInspector) |
Modifier and Type | Method and Description |
---|---|
protected List<ObjectInspector> |
MapJoinOperator.getValueObjectInspectors(byte alias,
List<ObjectInspector>[] aliasToObjectInspectors) |
protected List<ObjectInspector> |
CommonJoinOperator.getValueObjectInspectors(byte alias,
List<ObjectInspector>[] aliasToObjectInspectors) |
protected List<ObjectInspector> |
AbstractMapJoinOperator.getValueObjectInspectors(byte alias,
List<ObjectInspector>[] aliasToObjectInspectors) |
Modifier and Type | Method and Description |
---|---|
T |
FetchFormatter.convert(Object row,
ObjectInspector rowOI) |
Object |
FetchFormatter.ThriftFormatter.convert(Object row,
ObjectInspector rowOI) |
String |
DefaultFetchFormatter.convert(Object row,
ObjectInspector rowOI) |
protected void |
Operator.forward(Object row,
ObjectInspector rowInspector) |
void |
MuxOperator.forward(Object row,
ObjectInspector rowInspector) |
void |
DemuxOperator.forward(Object row,
ObjectInspector rowInspector) |
abstract void |
KeyWrapper.getNewKey(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(org.apache.hadoop.conf.Configuration hconf,
ObjectInspector[] inputOIs)
Initializes operators only if all parents have been initialized.
|
protected void |
Operator.initialize(org.apache.hadoop.conf.Configuration hconf,
ObjectInspector inputOI,
int parentId)
Collects all the parent's output object inspectors and calls actual
initialization method.
|
ObjectInspector |
ExprNodeGenericFuncEvaluator.initialize(ObjectInspector rowInspector) |
ObjectInspector |
ExprNodeFieldEvaluator.initialize(ObjectInspector rowInspector) |
ObjectInspector |
ExprNodeEvaluatorRef.initialize(ObjectInspector rowInspector) |
ObjectInspector |
ExprNodeEvaluatorHead.initialize(ObjectInspector rowInspector) |
abstract ObjectInspector |
ExprNodeEvaluator.initialize(ObjectInspector rowInspector)
Initialize should be called once and only once.
|
ObjectInspector |
ExprNodeConstantEvaluator.initialize(ObjectInspector rowInspector) |
ObjectInspector |
ExprNodeColumnEvaluator.initialize(ObjectInspector rowInspector) |
protected void |
CommonJoinOperator.internalForward(Object row,
ObjectInspector outputOI) |
void |
Operator.setInputObjInspectors(ObjectInspector[] inputObjInspectors) |
void |
ColumnInfo.setObjectinspector(ObjectInspector writableObjectInspector) |
protected void |
PTFOperator.setupKeysWrapper(ObjectInspector inputOI) |
protected void |
GroupByOperator.updateAggregations(GenericUDAFEvaluator.AggregationBuffer[] aggs,
Object row,
ObjectInspector rowInspector,
boolean hashAggr,
boolean newEntryForHashAggr,
Object[][] lastInvoke) |
Modifier and Type | Method and Description |
---|---|
static ArrayList<Object> |
JoinUtil.computeKeys(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 List<Object> |
JoinUtil.computeValues(Object row,
List<ExprNodeEvaluator> valueFields,
List<ObjectInspector> valueFieldsOI,
boolean hasFilter)
Return the value as a standard object.
|
GenericUDAFEvaluator |
Registry.getGenericUDAFEvaluator(String name,
List<ObjectInspector> argumentOIs,
boolean isDistinct,
boolean isAllColumns)
Get the GenericUDAF evaluator for the name and argumentClasses.
|
static GenericUDAFEvaluator |
FunctionRegistry.getGenericUDAFEvaluator(String name,
List<ObjectInspector> argumentOIs,
boolean isDistinct,
boolean isAllColumns)
Get the GenericUDAF evaluator for the name and argumentClasses.
|
GenericUDAFEvaluator |
Registry.getGenericWindowingEvaluator(String functionName,
List<ObjectInspector> argumentOIs,
boolean isDistinct,
boolean isAllColumns) |
static GenericUDAFEvaluator |
FunctionRegistry.getGenericWindowingEvaluator(String name,
List<ObjectInspector> argumentOIs,
boolean isDistinct,
boolean isAllColumns) |
static RowContainer<List<Object>> |
JoinUtil.getRowContainer(org.apache.hadoop.conf.Configuration hconf,
List<ObjectInspector> structFieldObjectInspectors,
Byte alias,
int containerSize,
TableDesc[] spillTableDesc,
JoinDesc conf,
boolean noFilter,
org.apache.hadoop.mapred.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.
|
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
MapJoinObjectSerDeContext.getStandardOI() |
Modifier and Type | Method and Description |
---|---|
static boolean |
MapJoinKey.isSupportedField(ObjectInspector foi) |
static boolean |
MapJoinBytesTableContainer.isSupportedKey(ObjectInspector keyOi) |
protected void |
MapJoinKeyObject.read(ObjectInspector oi,
Object obj) |
void |
RowContainer.setSerDe(SerDe sd,
ObjectInspector oi) |
Modifier and Type | Method and Description |
---|---|
static MapJoinKey |
MapJoinKey.readFromRow(ByteStream.Output output,
MapJoinKey key,
Object[] keyObject,
List<ObjectInspector> keyFieldsOI,
boolean mayReuseKey) |
void |
MapJoinKeyObject.readFromRow(Object[] fieldObjs,
List<ObjectInspector> keyFieldsOI) |
static MapJoinKey |
MapJoinKey.readFromVector(ByteStream.Output output,
MapJoinKey key,
Object[] keyObject,
List<ObjectInspector> keyOIs,
boolean mayReuseKey) |
static ByteStream.Output |
MapJoinKey.serializeRow(ByteStream.Output byteStream,
Object[] fieldData,
List<ObjectInspector> fieldOis,
boolean[] sortableSortOrders)
Serializes row to output.
|
JoinUtil.JoinResult |
MapJoinTableContainer.ReusableGetAdaptor.setFromRow(Object row,
List<ExprNodeEvaluator> fields,
List<ObjectInspector> ois)
Changes current rows to which adaptor is referring to the rows corresponding to
the key represented by a row object, and fields and ois used to interpret it.
|
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
ReduceRecordSource.getObjectInspector() |
Constructor and Description |
---|
KeyValueInputMerger(List<org.apache.tez.runtime.library.api.KeyValueReader> multiMRInputs,
Deserializer deserializer,
ObjectInspector[] inputObjInspectors,
List<String> sortCols) |
Modifier and Type | Field and Description |
---|---|
protected Map<ObjectInspector,VectorAssignRowSameBatch> |
VectorMapJoinBaseOperator.outputVectorAssignRowMap |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
VectorizedColumnarSerDe.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
static VectorColumnAssign[] |
VectorColumnAssignFactory.buildAssigners(VectorizedRowBatch outputBatch,
ObjectInspector outputOI,
Map<String,Integer> columnMap,
List<String> outputColumnNames)
Builds the assigners from an object inspector and from a list of columns.
|
static VectorColumnAssign |
VectorColumnAssignFactory.buildObjectAssign(VectorizedRowBatch outputBatch,
int outColIndex,
ObjectInspector objInspector) |
void |
VectorHashKeyWrapper.getNewKey(Object row,
ObjectInspector rowInspector) |
protected void |
VectorSMBMapJoinOperator.internalForward(Object row,
ObjectInspector outputOI) |
protected void |
VectorMapJoinBaseOperator.internalForward(Object row,
ObjectInspector outputOI)
'forwards' the (row-mode) record into the (vectorized) output batch
|
org.apache.hadoop.io.Writable |
VectorizedColumnarSerDe.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
VectorizedSerde.serializeVector(VectorizedRowBatch vrg,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
VectorizedColumnarSerDe.serializeVector(VectorizedRowBatch vrg,
ObjectInspector objInspector)
Serialize a vectorized row batch
|
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
VectorExpressionWriter.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
void |
VectorExpressionWriterFactory.SingleOIDClosure.assign(VectorExpressionWriter[] writers,
ObjectInspector objectInspector) |
static VectorExpressionWriter |
VectorExpressionWriterFactory.genVectorExpressionWritable(ObjectInspector fieldObjInspector)
Compiles the appropriate vector expression writer based on an expression info (ExprNodeDesc)
|
Modifier and Type | Method and Description |
---|---|
void |
VectorExpressionWriterFactory.ListOIDClosure.assign(VectorExpressionWriter[] writers,
List<ObjectInspector> oids) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
VectorUDAFSumDecimal.getOutputObjectInspector() |
ObjectInspector |
VectorUDAFCountStar.getOutputObjectInspector() |
ObjectInspector |
VectorUDAFCountMerge.getOutputObjectInspector() |
ObjectInspector |
VectorUDAFCount.getOutputObjectInspector() |
ObjectInspector |
VectorUDAFAvgDecimal.getOutputObjectInspector() |
abstract ObjectInspector |
VectorAggregateExpression.getOutputObjectInspector() |
Modifier and Type | Field and Description |
---|---|
ObjectInspector |
RecordIdentifier.Field.fieldOI |
static ObjectInspector |
RecordIdentifier.StructInfo.oi |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
AcidOutputFormat.Options.getInspector() |
ObjectInspector |
AcidInputFormat.RowReader.getObjectInspector() |
ObjectInspector |
AcidInputFormat.RawReader.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
static RecordUpdater |
HiveFileFormatUtils.getAcidRecordUpdater(org.apache.hadoop.mapred.JobConf jc,
TableDesc tableInfo,
int bucket,
FileSinkDesc conf,
org.apache.hadoop.fs.Path outPath,
ObjectInspector inspector,
org.apache.hadoop.mapred.Reporter reporter,
int rowIdColNum) |
AcidOutputFormat.Options |
AcidOutputFormat.Options.inspector(ObjectInspector inspector)
Use the given ObjectInspector for each record written.
|
Modifier and Type | Method and Description |
---|---|
static ObjectInspector |
OrcStruct.createObjectInspector(TypeInfo info) |
ObjectInspector |
ReaderImpl.getObjectInspector() |
ObjectInspector |
Reader.getObjectInspector()
Get the object inspector for looking at the objects.
|
ObjectInspector |
OrcSerde.getObjectInspector() |
ObjectInspector |
OrcRawRecordMerger.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
static Writer |
OrcFile.createWriter(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf,
ObjectInspector inspector,
long stripeSize,
CompressionKind compress,
int bufferSize,
int rowIndexStride)
Create an ORC file writer.
|
static int |
OrcUtils.getFlattenedColumnsCount(ObjectInspector inspector)
Returns the number of columns after flatting complex types.
|
static boolean[] |
OrcUtils.includeColumns(String selectedColumns,
String allColumns,
ObjectInspector inspector)
Returns selected columns as a boolean array with true value set for specified column names.
|
OrcFile.WriterOptions |
OrcFile.WriterOptions.inspector(ObjectInspector value)
A required option that sets the object inspector for the rows.
|
org.apache.hadoop.io.Writable |
VectorizedOrcSerde.serialize(Object obj,
ObjectInspector inspector) |
org.apache.hadoop.io.Writable |
OrcSerde.serialize(Object realRow,
ObjectInspector inspector) |
org.apache.hadoop.io.Writable |
OrcSerde.serializeVector(VectorizedRowBatch vrg,
ObjectInspector objInspector) |
Constructor and Description |
---|
VectorizedOrcSerde(ObjectInspector objInspector) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractParquetMapInspector |
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. |
class |
DeepParquetHiveMapInspector
The DeepParquetHiveMapInspector will inspect an ArrayWritable, considering it as a Hive map.
It can also inspect a Map if Hive decides to inspect the result of an inspection. When trying to access elements from the map it will iterate over all keys, inspecting them and comparing them to the desired key. |
class |
ParquetHiveArrayInspector
The ParquetHiveArrayInspector will inspect an ArrayWritable, considering it as an Hive array.
It can also inspect a List if Hive decides to inspect the result of an inspection. |
class |
StandardParquetHiveMapInspector
The StandardParquetHiveMapInspector will inspect an ArrayWritable, considering it as a Hive map.
It can also inspect a Map if Hive decides to inspect the result of an inspection. |
Modifier and Type | Field and Description |
---|---|
protected ObjectInspector |
AbstractParquetMapInspector.keyInspector |
protected ObjectInspector |
AbstractParquetMapInspector.valueInspector |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
ParquetHiveArrayInspector.getListElementObjectInspector() |
ObjectInspector |
AbstractParquetMapInspector.getMapKeyObjectInspector() |
ObjectInspector |
AbstractParquetMapInspector.getMapValueObjectInspector() |
ObjectInspector |
ParquetHiveSerDe.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.io.Writable |
ParquetHiveSerDe.serialize(Object obj,
ObjectInspector objInspector) |
Constructor and Description |
---|
AbstractParquetMapInspector(ObjectInspector keyInspector,
ObjectInspector valueInspector) |
DeepParquetHiveMapInspector(ObjectInspector keyInspector,
ObjectInspector valueInspector) |
ParquetHiveArrayInspector(ObjectInspector arrayElementInspector) |
StandardParquetHiveMapInspector(ObjectInspector keyInspector,
ObjectInspector valueInspector) |
Modifier and Type | Class and Description |
---|---|
class |
ParquetByteInspector
The ParquetByteInspector can inspect both ByteWritables and IntWritables into bytes.
|
class |
ParquetShortInspector
The ParquetShortInspector can inspect both ShortWritables and IntWritables into shorts.
|
class |
ParquetStringInspector
The ParquetStringInspector inspects a BinaryWritable to give a Text or String.
|
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
VirtualColumn.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
protected static void |
PTFTranslator.validateComparable(ObjectInspector OI,
String errMsg) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
ReduceWork.getKeyObjectInspector() |
ObjectInspector |
ReduceWork.getValueObjectInspector() |
ObjectInspector |
ExprNodeGenericFuncDesc.getWritableObjectInspector() |
ObjectInspector |
ExprNodeDesc.getWritableObjectInspector() |
ObjectInspector |
ExprNodeColumnListDesc.getWritableObjectInspector() |
Constructor and Description |
---|
ExprNodeGenericFuncDesc(ObjectInspector oi,
GenericUDF genericUDF,
List<ExprNodeDesc> children) |
ExprNodeGenericFuncDesc(ObjectInspector oi,
GenericUDF genericUDF,
String funcText,
List<ExprNodeDesc> children) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
ValueBoundaryDef.getOI() |
ObjectInspector |
PTFExpressionDef.getOI() |
Modifier and Type | Method and Description |
---|---|
void |
PTFExpressionDef.setOI(ObjectInspector oI) |
Modifier and Type | Method and Description |
---|---|
static long |
StatsUtils.getAvgColLenOfVariableLengthTypes(HiveConf conf,
ObjectInspector oi,
String colType)
Get the raw data size of variable length data types
|
static long |
StatsUtils.getSizeOfComplexTypes(HiveConf conf,
ObjectInspector oi)
Get the size of complex data types
|
static long |
StatsUtils.getWritableSize(ObjectInspector oi,
Object value)
Get size of primitive data types based on their respective writable object inspector
|
Modifier and Type | Class and Description |
---|---|
static class |
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator<V,OI extends ObjectInspector> |
Modifier and Type | Field and Description |
---|---|
protected ObjectInspector[] |
GenericUDFBaseCompare.argumentOIs |
protected ObjectInspector |
GenericUDFBaseCompare.compareOI |
protected OI |
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.maxFieldOI |
protected OI |
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.minFieldOI |
protected ObjectInspector |
GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator.sumFieldOI |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
GenericUDFUtils.ReturnObjectInspectorResolver.get()
Returns the ObjectInspector of the return value.
|
ObjectInspector |
GenericUDFUtils.ReturnObjectInspectorResolver.get(ObjectInspector defaultOI) |
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 |
GenericUDAFVariance.GenericUDAFVarianceEvaluator.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 |
GenericUDAFStreamingEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFRank.GenericUDAFAbstractRankEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator.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 |
GenericUDAFNTile.GenericUDAFNTileEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFnGrams.GenericUDAFnGramEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFMkCollectionEvaluator.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 |
GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFLastValue.GenericUDAFLastValueEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
Initialize the evaluator.
|
ObjectInspector |
GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFCovariance.GenericUDAFCovarianceEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFCount.GenericUDAFCountEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.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 |
GenericUDAFBridge.GenericUDAFBridgeEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
UDFCurrentDB.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFWhen.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFUpper.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFUnion.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFTrunc.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFTranslate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToVarchar.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToUnixTimeStamp.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToIntervalYearMonth.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToIntervalDayTime.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToDecimal.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToDate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToChar.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToBinary.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFTimestamp.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFStruct.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFStringToMap.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSplit.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSoundex.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSortArray.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSize.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSentences.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFRound.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFReflect2.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFReflect.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFPrintf.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFPower.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPOr.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPNull.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPNotNull.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPNot.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPDTIPlus.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPDTIMinus.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPAnd.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFNvl.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFNextDay.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFNamedStruct.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMonthsBetween.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMapValues.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMapKeys.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMap.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMacro.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLower.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLocate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLevenshtein.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLeadLag.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLastDay.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFInstr.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFInitCap.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFInFile.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFIndex.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFIn.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFIf.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFHash.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFGreatest.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFFromUtcTimestamp.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFFormatNumber.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFFloorCeilBase.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFField.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFFactorial.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFEWAHBitmapEmpty.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFEncode.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFElt.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDecode.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDateSub.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDateFormat.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDateDiff.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDateAdd.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCurrentUser.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCurrentTimestamp.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCurrentDate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFConcatWS.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFConcat.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCoalesce.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCbrt.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCase.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBridge.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBetween.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseUnary.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseTrim.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBasePad.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseNumeric.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseCompare.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseArithmetic.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFAssertTrue.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFArrayContains.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFArray.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFAddMonths.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFAbs.initialize(ObjectInspector[] arguments) |
abstract ObjectInspector |
GenericUDF.initialize(ObjectInspector[] arguments)
Initialize this GenericUDF.
|
ObjectInspector |
AbstractGenericUDFEWAHBitmapBop.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDF.initializeAndFoldConstants(ObjectInspector[] arguments)
Initialize this GenericUDF.
|
Modifier and Type | Method and Description |
---|---|
protected void |
GenericUDF.checkArgGroups(ObjectInspector[] arguments,
int i,
PrimitiveObjectInspector.PrimitiveCategory[] inputTypes,
PrimitiveObjectInspectorUtils.PrimitiveGrouping... grps) |
protected void |
GenericUDF.checkArgPrimitive(ObjectInspector[] arguments,
int i) |
protected void |
GenericUDF.checkArgsSize(ObjectInspector[] arguments,
int min,
int max) |
protected void |
GenericUDFSoundex.checkIfPrimitive(ObjectInspector[] arguments,
int i,
String argOrder) |
protected void |
GenericUDFSoundex.checkIfStringGroup(ObjectInspector[] arguments,
int i,
String argOrder) |
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) |
Object |
GenericUDFUtils.ReturnObjectInspectorResolver.convertIfNecessary(Object o,
ObjectInspector oi,
boolean reuse)
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 |
GenericUDFUtils.ReturnObjectInspectorResolver.get(ObjectInspector defaultOI) |
protected Integer |
GenericUDF.getConstantIntValue(ObjectInspector[] arguments,
int i) |
protected Long |
GenericUDF.getConstantLongValue(ObjectInspector[] arguments,
int i) |
protected String |
GenericUDF.getConstantStringValue(ObjectInspector[] arguments,
int i) |
protected void |
GenericUDFSoundex.getStringConverter(ObjectInspector[] arguments,
int i,
String argOrder) |
ObjectInspector |
GenericUDAFVariance.GenericUDAFVarianceEvaluator.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 |
GenericUDAFStreamingEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFRowNumber.GenericUDAFRowNumberEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFRank.GenericUDAFAbstractRankEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFPercentRank.GenericUDAFPercentRankEvaluator.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 |
GenericUDAFNTile.GenericUDAFNTileEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFnGrams.GenericUDAFnGramEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFMkCollectionEvaluator.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 |
GenericUDAFLeadLag.GenericUDAFLeadLagEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFLastValue.GenericUDAFLastValueEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFHistogramNumeric.GenericUDAFHistogramNumericEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFFirstValue.GenericUDAFFirstValueEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFEWAHBitmap.GenericUDAFEWAHBitmapEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters)
Initialize the evaluator.
|
ObjectInspector |
GenericUDAFCumeDist.GenericUDAFCumeDistEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFCovariance.GenericUDAFCovarianceEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFCount.GenericUDAFCountEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFCorrelation.GenericUDAFCorrelationEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFContextNGrams.GenericUDAFContextNGramEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFComputeStats.GenericUDAFBooleanStatsEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFComputeStats.GenericUDAFNumericStatsEvaluator.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 |
GenericUDAFBridge.GenericUDAFBridgeEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
GenericUDAFAverage.AbstractGenericUDAFAverageEvaluator.init(GenericUDAFEvaluator.Mode m,
ObjectInspector[] parameters) |
ObjectInspector |
UDFCurrentDB.initialize(ObjectInspector[] arguments) |
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.
|
ObjectInspector |
GenericUDFWhen.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFUpper.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFUnion.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFTrunc.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFTranslate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToVarchar.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToUnixTimeStamp.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToIntervalYearMonth.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToIntervalDayTime.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToDecimal.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToDate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToChar.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFToBinary.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFTimestamp.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFStruct.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFStringToMap.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSplit.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSoundex.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSortArray.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSize.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFSentences.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFRound.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFReflect2.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFReflect.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFPrintf.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFPower.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPOr.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPNull.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPNotNull.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPNot.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPDTIPlus.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPDTIMinus.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFOPAnd.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFNvl.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFNextDay.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFNamedStruct.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMonthsBetween.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMapValues.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMapKeys.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMap.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFMacro.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLower.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLocate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLevenshtein.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLeadLag.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFLastDay.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFInstr.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFInitCap.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFInFile.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFIndex.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFIn.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFIf.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFHash.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFGreatest.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFFromUtcTimestamp.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFFormatNumber.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFFloorCeilBase.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFField.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFFactorial.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFEWAHBitmapEmpty.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFEncode.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFElt.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDecode.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDateSub.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDateFormat.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDateDiff.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDateAdd.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFDate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCurrentUser.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCurrentTimestamp.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCurrentDate.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFConcatWS.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFConcat.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCoalesce.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCbrt.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFCase.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBridge.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBetween.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseUnary.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseTrim.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBasePad.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseNumeric.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseCompare.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFBaseArithmetic.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFAssertTrue.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFArrayContains.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFArray.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFAddMonths.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDFAbs.initialize(ObjectInspector[] arguments) |
abstract ObjectInspector |
GenericUDF.initialize(ObjectInspector[] arguments)
Initialize this GenericUDF.
|
ObjectInspector |
AbstractGenericUDFEWAHBitmapBop.initialize(ObjectInspector[] arguments) |
ObjectInspector |
GenericUDF.initializeAndFoldConstants(ObjectInspector[] arguments)
Initialize this GenericUDF.
|
protected void |
GenericUDFUnixTimeStamp.initializeInput(ObjectInspector[] arguments) |
protected void |
GenericUDFToUnixTimeStamp.initializeInput(ObjectInspector[] arguments) |
protected boolean |
GenericUDFConcatWS.isStringOrVoidType(ObjectInspector oi) |
protected void |
GenericUDF.obtainDateConverter(ObjectInspector[] arguments,
int i,
PrimitiveObjectInspector.PrimitiveCategory[] inputTypes,
ObjectInspectorConverters.Converter[] converters) |
protected void |
GenericUDF.obtainDoubleConverter(ObjectInspector[] arguments,
int i,
PrimitiveObjectInspector.PrimitiveCategory[] inputTypes,
ObjectInspectorConverters.Converter[] converters) |
protected void |
GenericUDF.obtainIntConverter(ObjectInspector[] arguments,
int i,
PrimitiveObjectInspector.PrimitiveCategory[] inputTypes,
ObjectInspectorConverters.Converter[] converters) |
protected void |
GenericUDF.obtainLongConverter(ObjectInspector[] arguments,
int i,
PrimitiveObjectInspector.PrimitiveCategory[] inputTypes,
ObjectInspectorConverters.Converter[] converters) |
protected void |
GenericUDF.obtainStringConverter(ObjectInspector[] arguments,
int i,
PrimitiveObjectInspector.PrimitiveCategory[] inputTypes,
ObjectInspectorConverters.Converter[] converters) |
protected void |
GenericUDF.obtainTimestampConverter(ObjectInspector[] arguments,
int i,
PrimitiveObjectInspector.PrimitiveCategory[] inputTypes,
ObjectInspectorConverters.Converter[] converters) |
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.
|
boolean |
GenericUDFUtils.ReturnObjectInspectorResolver.updateForUnionAll(ObjectInspector oi)
Update returnObjectInspector and valueInspectorsAreTheSame based on the
ObjectInspector seen for UnionAll.
|
Constructor and Description |
---|
GenericUDFUtils.ConversionHelper(Method m,
ObjectInspector[] parameterOIs)
Create a PrimitiveConversionHelper for Method m.
|
SimpleGenericUDAFParameterInfo(ObjectInspector[] params,
boolean distinct,
boolean allColumns) |
Modifier and Type | Method and Description |
---|---|
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) |
Constructor and Description |
---|
MatchPath.Symbol(ExprNodeEvaluator symbolExprEval,
ObjectInspector symbolOI) |
Constructor and Description |
---|
MatchPath.SymbolParser(String patternStr,
ArrayList<String> symbolNames,
ArrayList<ExprNodeEvaluator> symbolExprEvals,
ArrayList<ObjectInspector> symbolExprOIs) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
GenericUDFXPath.initialize(ObjectInspector[] arguments) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
GenericUDFXPath.initialize(ObjectInspector[] arguments) |
Modifier and Type | Class and Description |
---|---|
class |
BaseStructObjectInspector |
static class |
NullStructSerDe.NullStructSerDeObjectInspector
A object inspector for null struct serde.
|
Modifier and Type | Field and Description |
---|---|
protected ObjectInspector |
BaseStructObjectInspector.MyField.fieldObjectInspector |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
BaseStructObjectInspector.MyField.getFieldObjectInspector() |
ObjectInspector |
TypedSerDe.getObjectInspector() |
ObjectInspector |
RegexSerDe.getObjectInspector() |
ObjectInspector |
OpenCSVSerde.getObjectInspector() |
ObjectInspector |
NullStructSerDe.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 |
AbstractSerDe.getObjectInspector()
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(...).
|
Modifier and Type | Method and Description |
---|---|
protected BaseStructObjectInspector.MyField |
BaseStructObjectInspector.createField(int index,
String fieldName,
ObjectInspector fieldOI,
String comment) |
protected abstract org.apache.hadoop.io.Writable |
AbstractEncodingAwareSerDe.doSerialize(Object obj,
ObjectInspector objInspector) |
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.
|
org.apache.hadoop.io.Writable |
TypedSerDe.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
Serializer.serialize(Object obj,
ObjectInspector objInspector)
Deprecated.
Serialize an object by navigating inside the Object with the
ObjectInspector.
|
org.apache.hadoop.io.Writable |
RegexSerDe.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
OpenCSVSerde.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
NullStructSerDe.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
MetadataTypedColumnsetSerDe.serialize(Object obj,
ObjectInspector objInspector) |
abstract org.apache.hadoop.io.Writable |
AbstractSerializer.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object by navigating inside the Object with the
ObjectInspector.
|
abstract org.apache.hadoop.io.Writable |
AbstractSerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object by navigating inside the Object with the
ObjectInspector.
|
org.apache.hadoop.io.Writable |
AbstractEncodingAwareSerDe.serialize(Object obj,
ObjectInspector objInspector) |
protected void |
DelimitedJSONSerDe.serializeField(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
LazySerDeParameters serdeParams) |
static Object |
SerDeUtils.toThriftPayload(Object val,
ObjectInspector valOI,
int version)
Convert a Object to a standard Java object in compliance with JDBC 3.0 (see JDBC 3.0
Specification, Table B-3: Mapping from JDBC Types to Java Object Types).
|
Modifier and Type | Method and Description |
---|---|
protected void |
BaseStructObjectInspector.init(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments) |
Constructor and Description |
---|
BaseStructObjectInspector.MyField(int fieldID,
String fieldName,
ObjectInspector fieldObjectInspector,
String fieldComment) |
Constructor and Description |
---|
BaseStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors)
Call ObjectInspectorFactory.getLazySimpleStructObjectInspector instead.
|
BaseStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments) |
Modifier and Type | Class and Description |
---|---|
class |
AvroLazyObjectInspector
Lazy objectinspector for avro serialization
|
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
AvroSerDe.getObjectInspector() |
ObjectInspector |
AvroObjectInspectorGenerator.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.io.Writable |
AvroSerDe.serialize(Object o,
ObjectInspector objectInspector) |
Constructor and Description |
---|
AvroLazyObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
LazyObjectInspectorParameters lazyParams) |
AvroLazyObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
BinarySortableSerDe.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.io.Writable |
BinarySortableSerDe.serialize(Object obj,
ObjectInspector objInspector) |
Modifier and Type | Method and Description |
---|---|
static void |
BinarySortableSerDe.serializeStruct(ByteStream.Output byteStream,
Object[] fieldData,
List<ObjectInspector> fieldOis,
boolean[] sortableSortOrders) |
Modifier and Type | Field and Description |
---|---|
protected ObjectInspector |
ColumnarSerDeBase.cachedObjectInspector |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
ColumnarSerDeBase.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
protected LazyObjectBase |
LazyBinaryColumnarStruct.createLazyObjectBase(ObjectInspector objectInspector) |
protected abstract LazyObjectBase |
ColumnarStructBase.createLazyObjectBase(ObjectInspector objectInspector)
create the lazy object for this field
|
protected LazyObjectBase |
ColumnarStruct.createLazyObjectBase(ObjectInspector objectInspector) |
protected int |
LazyBinaryColumnarStruct.getLength(ObjectInspector objectInspector,
ByteArrayRef cachedByteArrayRef,
int start,
int length) |
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
|
protected int |
ColumnarStruct.getLength(ObjectInspector objectInspector,
ByteArrayRef cachedByteArrayRef,
int start,
int fieldLen) |
org.apache.hadoop.io.Writable |
LazyBinaryColumnarSerDe.serialize(Object obj,
ObjectInspector objInspector) |
org.apache.hadoop.io.Writable |
ColumnarSerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize a row of data.
|
Constructor and Description |
---|
ColumnarStruct(ObjectInspector oi,
List<Integer> notSkippedColumnIDs,
org.apache.hadoop.io.Text nullSequence)
Construct a ColumnarStruct object with the TypeInfo.
|
ColumnarStructBase(ObjectInspector oi,
List<Integer> notSkippedColumnIDs) |
LazyBinaryColumnarStruct(ObjectInspector oi,
List<Integer> notSkippedColumnIDs) |
Modifier and Type | Method and Description |
---|---|
static ObjectInspector |
DynamicSerDe.dynamicSerDeStructBaseToObjectInspector(DynamicSerDeTypeBase bt) |
ObjectInspector |
DynamicSerDe.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.io.Writable |
DynamicSerDe.serialize(Object obj,
ObjectInspector objInspector) |
void |
DynamicSerDeTypeString.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 |
DynamicSerDeTypeList.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 |
DynamicSerDeTypeDouble.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 |
DynamicSerDeTypeByte.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot) |
void |
DynamicSerDeTypeBool.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.
|
void |
DynamicSerDeFieldList.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot) |
Modifier and Type | Class and Description |
---|---|
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 org.apache.hadoop.io.Writable>
LazyPrimitive stores a primitive Object in a LazyObject.
|
Modifier and Type | Field and Description |
---|---|
protected OI |
LazyObject.oi |
Modifier and Type | Method and Description |
---|---|
static ObjectInspector |
LazyFactory.createColumnarStructInspector(List<String> columnNames,
List<TypeInfo> columnTypes,
byte[] separators,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Deprecated.
|
static ObjectInspector |
LazyFactory.createColumnarStructInspector(List<String> columnNames,
List<TypeInfo> columnTypes,
LazyObjectInspectorParameters lazyParams)
Create a hierarchical ObjectInspector for ColumnarStruct with the given
columnNames and columnTypeInfos.
|
static ObjectInspector |
LazyFactory.createLazyObjectInspector(TypeInfo typeInfo,
byte[] separators,
int separatorIndex,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Deprecated.
|
static ObjectInspector |
LazyFactory.createLazyObjectInspector(TypeInfo typeInfo,
byte[] separators,
int separatorIndex,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar,
boolean extendedBooleanLiteral)
Deprecated.
|
static ObjectInspector |
LazyFactory.createLazyObjectInspector(TypeInfo typeInfo,
byte[] separators,
int separatorIndex,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar,
boolean extendedBooleanLiteral,
ObjectInspectorFactory.ObjectInspectorOptions option)
Deprecated.
|
static ObjectInspector |
LazyFactory.createLazyObjectInspector(TypeInfo typeInfo,
byte[] separators,
int separatorIndex,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar,
ObjectInspectorFactory.ObjectInspectorOptions option)
Deprecated.
|
static ObjectInspector |
LazyFactory.createLazyObjectInspector(TypeInfo typeInfo,
int separatorIndex,
LazyObjectInspectorParameters lazyParams,
ObjectInspectorFactory.ObjectInspectorOptions option)
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)
Deprecated.
|
static ObjectInspector |
LazyFactory.createLazyStructInspector(List<String> columnNames,
List<TypeInfo> typeInfos,
byte[] separators,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar,
boolean extendedBooleanLiteral)
Deprecated.
|
static ObjectInspector |
LazyFactory.createLazyStructInspector(List<String> columnNames,
List<TypeInfo> typeInfos,
LazyObjectInspectorParameters lazyParams)
Create a hierarchical ObjectInspector for LazyStruct with the given
columnNames and columnTypeInfos.
|
ObjectInspector |
LazySimpleSerDe.getObjectInspector()
Returns the ObjectInspector for the row.
|
Modifier and Type | Method and Description |
---|---|
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 org.apache.hadoop.io.Writable> |
LazyFactory.createLazyPrimitiveBinaryClass(PrimitiveObjectInspector poi) |
static LazyPrimitive<? extends ObjectInspector,? extends org.apache.hadoop.io.Writable> |
LazyFactory.createLazyPrimitiveClass(PrimitiveObjectInspector oi)
Create a lazy primitive class given the type name.
|
static LazyPrimitive<? extends ObjectInspector,? extends org.apache.hadoop.io.Writable> |
LazyFactory.createLazyPrimitiveClass(PrimitiveObjectInspector poi,
boolean typeBinary)
Create a lazy primitive object instance given a primitive object inspector based on it's
type.
|
Modifier and Type | Method and Description |
---|---|
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.
|
org.apache.hadoop.io.Writable |
LazySimpleSerDe.doSerialize(Object obj,
ObjectInspector objInspector)
Serialize a row of data.
|
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.
|
protected void |
LazySimpleSerDe.serializeField(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
LazySerDeParameters serdeParams) |
Modifier and Type | Class and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
LazyListObjectInspector.getListElementObjectInspector() |
ObjectInspector |
LazyMapObjectInspector.getMapKeyObjectInspector() |
ObjectInspector |
LazyMapObjectInspector.getMapValueObjectInspector() |
Modifier and Type | Method and Description |
---|---|
List<ObjectInspector> |
LazyUnionObjectInspector.getObjectInspectors() |
Modifier and Type | Method and Description |
---|---|
static LazyListObjectInspector |
LazyObjectInspectorFactory.getLazySimpleListObjectInspector(ObjectInspector listElementObjectInspector,
byte separator,
LazyObjectInspectorParameters lazyParams) |
static LazyListObjectInspector |
LazyObjectInspectorFactory.getLazySimpleListObjectInspector(ObjectInspector listElementObjectInspector,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Deprecated.
|
static LazyMapObjectInspector |
LazyObjectInspectorFactory.getLazySimpleMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector,
byte itemSeparator,
byte keyValueSeparator,
LazyObjectInspectorParameters lazyParams) |
static LazyMapObjectInspector |
LazyObjectInspectorFactory.getLazySimpleMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector,
byte itemSeparator,
byte keyValueSeparator,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static LazySimpleStructObjectInspector |
LazyObjectInspectorFactory.getLazySimpleStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar)
Deprecated.
|
static LazySimpleStructObjectInspector |
LazyObjectInspectorFactory.getLazySimpleStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar,
ObjectInspectorFactory.ObjectInspectorOptions option)
Deprecated.
|
static LazySimpleStructObjectInspector |
LazyObjectInspectorFactory.getLazySimpleStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
LazyObjectInspectorParameters lazyParams,
ObjectInspectorFactory.ObjectInspectorOptions option) |
static LazySimpleStructObjectInspector |
LazyObjectInspectorFactory.getLazySimpleStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar)
Deprecated.
|
static LazySimpleStructObjectInspector |
LazyObjectInspectorFactory.getLazySimpleStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar,
ObjectInspectorFactory.ObjectInspectorOptions option)
Deprecated.
|
static LazyUnionObjectInspector |
LazyObjectInspectorFactory.getLazyUnionObjectInspector(List<ObjectInspector> ois,
byte separator,
LazyObjectInspectorParameters lazyParams) |
static LazyUnionObjectInspector |
LazyObjectInspectorFactory.getLazyUnionObjectInspector(List<ObjectInspector> ois,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Deprecated.
|
protected void |
LazyUnionObjectInspector.init(List<ObjectInspector> ois,
byte separator,
LazyObjectInspectorParameters lazyParams) |
protected void |
LazySimpleStructObjectInspector.init(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
LazyObjectInspectorParameters lazyParams) |
protected void |
LazySimpleStructObjectInspector.init(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar) |
Constructor and Description |
---|
LazyListObjectInspector(ObjectInspector listElementObjectInspector,
byte separator,
LazyObjectInspectorParameters lazyParams)
Call ObjectInspectorFactory.getLazySimpleListObjectInspector instead.
|
LazyMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector,
byte itemSeparator,
byte keyValueSeparator,
LazyObjectInspectorParameters lazyParams) |
LazyMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector,
byte itemSeparator,
byte keyValueSeparator,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Call ObjectInspectorFactory.getStandardListObjectInspector instead.
|
Constructor and Description |
---|
LazySimpleStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar)
Deprecated.
|
LazySimpleStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
LazyObjectInspectorParameters lazyParams) |
LazySimpleStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments,
byte separator,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar)
Deprecated.
|
LazyUnionObjectInspector(List<ObjectInspector> ois,
byte separator,
LazyObjectInspectorParameters lazyParams) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPrimitiveLazyObjectInspector<T extends org.apache.hadoop.io.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 |
LazyHiveCharObjectInspector |
class |
LazyHiveDecimalObjectInspector |
class |
LazyHiveIntervalDayTimeObjectInspector |
class |
LazyHiveIntervalYearMonthObjectInspector |
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.
|
Modifier and Type | Class and Description |
---|---|
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 org.apache.hadoop.io.Writable>
Defines a LazyBinaryPrimitive.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
static void |
LazyBinaryUtils.checkObjectByteInfo(ObjectInspector objectInspector,
byte[] bytes,
int offset,
LazyBinaryUtils.RecordInfo recordInfo,
LazyBinaryUtils.VInt vInt)
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 void |
LazyBinarySerDe.serialize(ByteStream.RandomAccessOutput byteStream,
Object obj,
ObjectInspector objInspector,
boolean skipLengthPrefix,
LazyBinarySerDe.BooleanRef warnedOnceNullMapKey)
A recursive function that serialize an object to a byte buffer based on its
object inspector.
|
org.apache.hadoop.io.Writable |
LazyBinarySerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object to a byte buffer in a binary compact way.
|
Modifier and Type | Method and Description |
---|---|
static void |
LazyBinarySerDe.serializeStruct(ByteStream.RandomAccessOutput byteStream,
Object[] fieldData,
List<ObjectInspector> fieldOis) |
Modifier and Type | Class and Description |
---|---|
class |
LazyBinaryListObjectInspector
ObjectInspector for LazyBinaryList.
|
class |
LazyBinaryMapObjectInspector
ObjectInspector for LazyBinaryMap.
|
class |
LazyBinaryStructObjectInspector
ObjectInspector for LazyBinaryStruct.
|
class |
LazyBinaryUnionObjectInspector
ObjectInspector for LazyBinaryUnion.
|
Modifier and Type | Method and Description |
---|---|
static LazyBinaryListObjectInspector |
LazyBinaryObjectInspectorFactory.getLazyBinaryListObjectInspector(ObjectInspector listElementObjectInspector) |
static LazyBinaryMapObjectInspector |
LazyBinaryObjectInspectorFactory.getLazyBinaryMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector) |
Modifier and Type | Method and Description |
---|---|
static LazyBinaryStructObjectInspector |
LazyBinaryObjectInspectorFactory.getLazyBinaryStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors) |
static LazyBinaryStructObjectInspector |
LazyBinaryObjectInspectorFactory.getLazyBinaryStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments) |
static LazyBinaryUnionObjectInspector |
LazyBinaryObjectInspectorFactory.getLazyBinaryUnionObjectInspector(List<ObjectInspector> unionFieldObjectInspectors) |
Constructor and Description |
---|
LazyBinaryListObjectInspector(ObjectInspector listElementObjectInspector) |
LazyBinaryMapObjectInspector(ObjectInspector mapKeyObjectInspector,
ObjectInspector mapValueObjectInspector) |
Constructor and Description |
---|
LazyBinaryStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors) |
LazyBinaryStructObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments) |
LazyBinaryUnionObjectInspector(List<ObjectInspector> unionFieldObjectInspectors) |
Modifier and Type | Interface and Description |
---|---|
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.
|
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 |
SettableUnionObjectInspector
SettableUnionObjectInspector.
|
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 |
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 ObjectInspector |
StandardStructObjectInspector.MyField.fieldObjectInspector |
protected ObjectInspector |
ReflectionStructObjectInspector.MyField.fieldObjectInspector |
ObjectInspector |
InspectableObject.oi |
Modifier and Type | Method and Description |
---|---|
static ObjectInspector |
ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI,
ObjectInspector outputOI) |
static ObjectInspector |
ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI,
ObjectInspector outputOI,
Map<ObjectInspector,Boolean> oiSettableProperties) |
static ObjectInspector |
ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI,
ObjectInspector outputOI,
Map<ObjectInspector,Boolean> oiSettableProperties,
boolean equalsCheck)
Utility function to convert from one object inspector type to another.
|
ObjectInspector |
UnionStructObjectInspector.MyField.getFieldObjectInspector() |
ObjectInspector |
StructField.getFieldObjectInspector()
Get the ObjectInspector for the field.
|
ObjectInspector |
StandardStructObjectInspector.MyField.getFieldObjectInspector() |
ObjectInspector |
ReflectionStructObjectInspector.MyField.getFieldObjectInspector() |
ObjectInspector |
StandardListObjectInspector.getListElementObjectInspector() |
ObjectInspector |
ListObjectInspector.getListElementObjectInspector() |
ObjectInspector |
StandardMapObjectInspector.getMapKeyObjectInspector() |
ObjectInspector |
MapObjectInspector.getMapKeyObjectInspector() |
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.
|
Modifier and Type | Method and Description |
---|---|
protected List<? extends ObjectInspector> |
ReflectionStructObjectInspector.extractFieldObjectInspectors(Class<?> clazz,
ObjectInspectorFactory.ObjectInspectorOptions options) |
List<ObjectInspector> |
UnionObjectInspector.getObjectInspectors()
Returns the array of ObjectInspectors that are for each of the tags.
|
List<ObjectInspector> |
ThriftUnionObjectInspector.getObjectInspectors() |
List<ObjectInspector> |
StandardUnionObjectInspector.getObjectInspectors() |
Modifier and Type | Method and Description |
---|---|
Object |
StandardUnionObjectInspector.addField(Object union,
ObjectInspector oi) |
abstract Object |
SettableUnionObjectInspector.addField(Object union,
ObjectInspector oi) |
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 void |
ObjectInspectorUtils.copyStructToArray(Object o,
ObjectInspector oi,
ObjectInspectorUtils.ObjectInspectorCopyOption objectInspectorOption,
Object[] dest,
int offset) |
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) |
static ObjectInspector |
ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI,
ObjectInspector outputOI,
Map<ObjectInspector,Boolean> oiSettableProperties) |
static ObjectInspector |
ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI,
ObjectInspector outputOI,
Map<ObjectInspector,Boolean> oiSettableProperties,
boolean equalsCheck)
Utility function to convert from one object inspector type to another.
|
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 int |
ObjectInspectorUtils.getStructSize(ObjectInspector oi) |
static Object |
ObjectInspectorUtils.getWritableConstantValue(ObjectInspector oi) |
static ObjectInspector |
ObjectInspectorUtils.getWritableObjectInspector(ObjectInspector oi)
Ensures that an ObjectInspector is Writable.
|
static Boolean |
ObjectInspectorUtils.hasAllFieldsSettable(ObjectInspector oi) |
static boolean |
ObjectInspectorUtils.hasAllFieldsSettable(ObjectInspector oi,
Map<ObjectInspector,Boolean> oiSettableProperties) |
static int |
ObjectInspectorUtils.hashCode(Object o,
ObjectInspector objIns) |
static boolean |
ObjectInspectorUtils.isConstantObjectInspector(ObjectInspector oi) |
static boolean |
ObjectInspectorUtils.supportsConstantObjectInspector(ObjectInspector oi) |
Modifier and Type | Method and Description |
---|---|
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 ObjectInspector |
ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI,
ObjectInspector outputOI,
Map<ObjectInspector,Boolean> oiSettableProperties) |
static ObjectInspector |
ObjectInspectorConverters.getConvertedOI(ObjectInspector inputOI,
ObjectInspector outputOI,
Map<ObjectInspector,Boolean> oiSettableProperties,
boolean equalsCheck)
Utility function to convert from one object inspector type to another.
|
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) |
static boolean |
ObjectInspectorUtils.hasAllFieldsSettable(ObjectInspector oi,
Map<ObjectInspector,Boolean> oiSettableProperties) |
protected void |
StandardStructObjectInspector.init(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors,
List<String> structFieldComments) |
Constructor and Description |
---|
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) |
Modifier and Type | Interface and Description |
---|---|
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 |
HiveCharObjectInspector |
interface |
HiveDecimalObjectInspector
A DecimalObjectInspector inspects an Object representing a HiveDecimal.
|
interface |
HiveIntervalDayTimeObjectInspector
A HiveIntervalObjectInspector inspects an Object representing an Interval.
|
interface |
HiveIntervalYearMonthObjectInspector
A HiveIntervalObjectInspector inspects an Object representing a year-month Interval.
|
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 |
SettableHiveCharObjectInspector |
interface |
SettableHiveDecimalObjectInspector
A SettableDecimalObjectInspector can set a HiveDecimal value to an object.
|
interface |
SettableHiveIntervalDayTimeObjectInspector
A SettableHiveIntervalDayTimeObjectInspector can set a IntervalDayTime value to an object.
|
interface |
SettableHiveIntervalYearMonthObjectInspector
A SettableHiveIntervalYearMonthObjectInspector can set a IntervalYearMonth 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.
|
Modifier and Type | Class and Description |
---|---|
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 |
JavaConstantBinaryObjectInspector |
class |
JavaConstantBooleanObjectInspector |
class |
JavaConstantByteObjectInspector |
class |
JavaConstantDateObjectInspector |
class |
JavaConstantDoubleObjectInspector |
class |
JavaConstantFloatObjectInspector |
class |
JavaConstantHiveCharObjectInspector |
class |
JavaConstantHiveDecimalObjectInspector |
class |
JavaConstantHiveVarcharObjectInspector |
class |
JavaConstantIntObjectInspector |
class |
JavaConstantLongObjectInspector |
class |
JavaConstantShortObjectInspector |
class |
JavaConstantStringObjectInspector |
class |
JavaConstantTimestampObjectInspector |
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 |
JavaHiveCharObjectInspector |
class |
JavaHiveDecimalObjectInspector |
class |
JavaHiveIntervalDayTimeObjectInspector |
class |
JavaHiveIntervalYearMonthObjectInspector |
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 |
WritableConstantHiveCharObjectInspector
A WritableConstantHiveCharObjectInspector is a WritableHiveCharObjectInspector
that implements ConstantObjectInspector.
|
class |
WritableConstantHiveDecimalObjectInspector
A WritableConstantHiveDecimalObjectInspector is a WritableHiveDecimalObjectInspector
that implements ConstantObjectInspector.
|
class |
WritableConstantHiveIntervalDayTimeObjectInspector |
class |
WritableConstantHiveIntervalYearMonthObjectInspector |
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 |
WritableHiveCharObjectInspector |
class |
WritableHiveDecimalObjectInspector |
class |
WritableHiveIntervalDayTimeObjectInspector |
class |
WritableHiveIntervalYearMonthObjectInspector |
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.
|
Modifier and Type | Method and Description |
---|---|
static Class<?> |
PrimitiveObjectInspectorUtils.getJavaPrimitiveClassFromObjectInspector(ObjectInspector oi) |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
ThriftDeserializer.getObjectInspector() |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
static TypeInfo |
TypeInfoUtils.getTypeInfoFromObjectInspector(ObjectInspector oi)
Get the TypeInfo object from the ObjectInspector object by recursively
going into the ObjectInspector structure.
|
Modifier and Type | Class and Description |
---|---|
class |
HCatRecordObjectInspector |
Modifier and Type | Method and Description |
---|---|
ObjectInspector |
JsonSerDe.getObjectInspector()
Returns an object inspector for the specified schema that
is capable of reading in the object representation of the JSON string
|
ObjectInspector |
HCatRecordSerDe.getObjectInspector()
Return an object inspector that can read through the object
that we return from deserialize().
|
static ObjectInspector |
HCatRecordObjectInspectorFactory.getStandardObjectInspectorFromTypeInfo(TypeInfo typeInfo) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.io.Writable |
JsonSerDe.serialize(Object obj,
ObjectInspector objInspector)
Given an object and object inspector pair, traverse the object
and generate a Text representation of the object.
|
org.apache.hadoop.io.Writable |
HCatRecordSerDe.serialize(Object obj,
ObjectInspector objInspector)
The purpose of the serialize method is to turn an object-representation
with a provided ObjectInspector into a Writable format, which
the underlying layer can then use to write out.
|
static Object |
HCatRecordSerDe.serializeField(Object field,
ObjectInspector fieldObjectInspector)
Return underlying Java Object from an object-representation
that is readable by a provided ObjectInspector.
|
Constructor and Description |
---|
LazyHCatRecord(Object wrappedObject,
ObjectInspector oi) |
Constructor and Description |
---|
HCatRecordObjectInspector(List<String> structFieldNames,
List<ObjectInspector> structFieldObjectInspectors) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.