|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of SerDeException in org.apache.hadoop.hive.serde2 |
---|
Methods in org.apache.hadoop.hive.serde2 that throw SerDeException | |
---|---|
abstract Object |
AbstractDeserializer.deserialize(org.apache.hadoop.io.Writable blob)
Deserialize an object out of a Writable blob. |
abstract Object |
AbstractSerDe.deserialize(org.apache.hadoop.io.Writable blob)
Deserialize an object out of a Writable blob. |
Object |
ByteStreamTypedSerDe.deserialize(org.apache.hadoop.io.Writable field)
|
Object |
DelimitedJSONSerDe.deserialize(org.apache.hadoop.io.Writable field)
Not implemented. |
Object |
Deserializer.deserialize(org.apache.hadoop.io.Writable blob)
Deprecated. Deserialize an object out of a Writable blob. |
Object |
MetadataTypedColumnsetSerDe.deserialize(org.apache.hadoop.io.Writable field)
|
Object |
NullStructSerDe.deserialize(org.apache.hadoop.io.Writable blob)
|
Object |
RegexSerDe.deserialize(org.apache.hadoop.io.Writable blob)
|
Object |
TypedSerDe.deserialize(org.apache.hadoop.io.Writable blob)
|
abstract ObjectInspector |
AbstractDeserializer.getObjectInspector()
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(...). |
ObjectInspector |
Deserializer.getObjectInspector()
Deprecated. Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...). |
ObjectInspector |
MetadataTypedColumnsetSerDe.getObjectInspector()
|
ObjectInspector |
NullStructSerDe.getObjectInspector()
|
ObjectInspector |
RegexSerDe.getObjectInspector()
|
ObjectInspector |
TypedSerDe.getObjectInspector()
|
abstract void |
AbstractDeserializer.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Initialize the HiveDeserializer. |
abstract void |
AbstractSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Initialize the HiveSerializer. |
abstract void |
AbstractSerializer.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Initialize the HiveSerializer. |
void |
Deserializer.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Deprecated. Initialize the HiveDeserializer. |
void |
MetadataTypedColumnsetSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
void |
NullStructSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
|
void |
RegexSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
|
void |
Serializer.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Deprecated. Initialize the HiveSerializer. |
void |
TypedSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
abstract org.apache.hadoop.io.Writable |
AbstractSerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object by navigating inside the Object with the ObjectInspector. |
abstract org.apache.hadoop.io.Writable |
AbstractSerializer.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object by navigating inside the Object with the ObjectInspector. |
org.apache.hadoop.io.Writable |
MetadataTypedColumnsetSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
org.apache.hadoop.io.Writable |
NullStructSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
org.apache.hadoop.io.Writable |
RegexSerDe.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 |
TypedSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
Constructors in org.apache.hadoop.hive.serde2 that throw SerDeException | |
---|---|
ByteStreamTypedSerDe(Type objectType)
|
|
DelimitedJSONSerDe()
|
|
MetadataTypedColumnsetSerDe()
|
|
TypedSerDe(Type objectType)
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.avro |
---|
Subclasses of SerDeException in org.apache.hadoop.hive.serde2.avro | |
---|---|
class |
AvroSerdeException
|
class |
BadSchemaException
|
Methods in org.apache.hadoop.hive.serde2.avro that throw SerDeException | |
---|---|
Object |
AvroSerDe.deserialize(org.apache.hadoop.io.Writable writable)
|
ObjectInspector |
AvroSerDe.getObjectInspector()
|
void |
AvroSerDe.initialize(org.apache.hadoop.conf.Configuration configuration,
Properties properties)
|
org.apache.hadoop.io.Writable |
AvroSerDe.serialize(Object o,
ObjectInspector objectInspector)
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.binarysortable |
---|
Methods in org.apache.hadoop.hive.serde2.binarysortable that throw SerDeException | |
---|---|
Object |
BinarySortableSerDe.deserialize(org.apache.hadoop.io.Writable blob)
|
ObjectInspector |
BinarySortableSerDe.getObjectInspector()
|
void |
BinarySortableSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
|
org.apache.hadoop.io.Writable |
BinarySortableSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.columnar |
---|
Methods in org.apache.hadoop.hive.serde2.columnar that throw SerDeException | |
---|---|
Object |
ColumnarSerDeBase.deserialize(org.apache.hadoop.io.Writable blob)
|
ObjectInspector |
ColumnarSerDeBase.getObjectInspector()
|
void |
ColumnarSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Initialize the SerDe given the parameters. |
void |
LazyBinaryColumnarSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
|
org.apache.hadoop.io.Writable |
ColumnarSerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize a row of data. |
org.apache.hadoop.io.Writable |
LazyBinaryColumnarSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
Constructors in org.apache.hadoop.hive.serde2.columnar that throw SerDeException | |
---|---|
ColumnarSerDe()
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.dynamic_type |
---|
Methods in org.apache.hadoop.hive.serde2.dynamic_type that throw SerDeException | |
---|---|
Object |
DynamicSerDeFieldList.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeStructBase.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
abstract Object |
DynamicSerDeTypeBase.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypeBool.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypeByte.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypedef.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypeDouble.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypei16.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypei32.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypei64.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
ArrayList<Object> |
DynamicSerDeTypeList.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Map<Object,Object> |
DynamicSerDeTypeMap.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypeSet.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
NOTE: Set is not supported by Hive yet. |
Object |
DynamicSerDeTypeString.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Byte |
DynamicSerDeTypeByte.deserialize(org.apache.thrift.protocol.TProtocol iprot)
|
String |
DynamicSerDeTypeString.deserialize(org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDe.deserialize(org.apache.hadoop.io.Writable field)
|
static ObjectInspector |
DynamicSerDe.dynamicSerDeStructBaseToObjectInspector(DynamicSerDeTypeBase bt)
|
ObjectInspector |
DynamicSerDe.getObjectInspector()
|
Class |
DynamicSerDeTypeBase.getRealType()
|
void |
DynamicSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
org.apache.hadoop.io.Writable |
DynamicSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
void |
DynamicSerDeFieldList.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. |
abstract void |
DynamicSerDeTypeBase.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
void |
DynamicSerDeTypeBool.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
void |
DynamicSerDeTypeByte.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 |
DynamicSerDeTypeDouble.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
void |
DynamicSerDeTypei16.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
void |
DynamicSerDeTypei32.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 |
DynamicSerDeTypeList.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 |
DynamicSerDeTypeSet.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
void |
DynamicSerDeTypeString.serialize(Object o,
ObjectInspector oi,
org.apache.thrift.protocol.TProtocol oprot)
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.lazy |
---|
Methods in org.apache.hadoop.hive.serde2.lazy that throw SerDeException | |
---|---|
static ObjectInspector |
LazyFactory.createColumnarStructInspector(List<String> columnNames,
List<TypeInfo> columnTypes,
byte[] separators,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Create a hierarchical ObjectInspector for ColumnarStruct with the given columnNames and columnTypeInfos. |
static ObjectInspector |
LazyFactory.createLazyObjectInspector(TypeInfo typeInfo,
byte[] separator,
int separatorIndex,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar)
Create a hierarchical ObjectInspector for LazyObject with the given typeInfo. |
static ObjectInspector |
LazyFactory.createLazyStructInspector(List<String> columnNames,
List<TypeInfo> typeInfos,
byte[] separators,
org.apache.hadoop.io.Text nullSequence,
boolean lastColumnTakesRest,
boolean escaped,
byte escapeChar)
Create a hierarchical ObjectInspector for LazyStruct with the given columnNames and columnTypeInfos. |
Object |
LazySimpleSerDe.deserialize(org.apache.hadoop.io.Writable field)
Deserialize a row from the Writable to a LazyObject. |
static void |
LazyUtils.extractColumnInfo(Properties tbl,
LazySimpleSerDe.SerDeParameters serdeParams,
String serdeName)
|
ObjectInspector |
LazySimpleSerDe.getObjectInspector()
Returns the ObjectInspector for the row. |
void |
LazySimpleSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
Initialize the SerDe given the parameters. |
static LazySimpleSerDe.SerDeParameters |
LazySimpleSerDe.initSerdeParams(org.apache.hadoop.conf.Configuration job,
Properties tbl,
String serdeName)
|
static void |
LazySimpleSerDe.serialize(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
byte[] separators,
int level,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar,
boolean[] needsEscape)
Serialize the row into the StringBuilder. |
org.apache.hadoop.io.Writable |
LazySimpleSerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize a row of data. |
Constructors in org.apache.hadoop.hive.serde2.lazy that throw SerDeException | |
---|---|
LazySimpleSerDe()
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.lazybinary |
---|
Methods in org.apache.hadoop.hive.serde2.lazybinary that throw SerDeException | |
---|---|
Object |
LazyBinarySerDe.deserialize(org.apache.hadoop.io.Writable field)
Deserialize a table record to a lazybinary struct. |
ObjectInspector |
LazyBinarySerDe.getObjectInspector()
Returns the ObjectInspector for the row. |
void |
LazyBinarySerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Initialize the SerDe with configuration and table information. |
static boolean |
LazyBinarySerDe.serialize(ByteStream.Output byteStream,
Object obj,
ObjectInspector objInspector,
boolean skipLengthPrefix,
boolean warnedOnceNullMapKey)
A recursive function that serialize an object to a byte buffer based on its object inspector. |
org.apache.hadoop.io.Writable |
LazyBinarySerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object to a byte buffer in a binary compact way. |
static void |
LazyBinarySerDe.serializeStruct(ByteStream.Output byteStream,
Object[] fieldData,
List<ObjectInspector> fieldOis)
|
Constructors in org.apache.hadoop.hive.serde2.lazybinary that throw SerDeException | |
---|---|
LazyBinarySerDe()
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.objectinspector |
---|
Methods in org.apache.hadoop.hive.serde2.objectinspector that throw SerDeException | |
---|---|
static void |
ObjectInspectorUtils.copyStructToArray(Object o,
ObjectInspector oi,
ObjectInspectorUtils.ObjectInspectorCopyOption objectInspectorOption,
Object[] dest,
int offset)
|
static int |
ObjectInspectorUtils.getStructSize(ObjectInspector oi)
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.thrift |
---|
Methods in org.apache.hadoop.hive.serde2.thrift that throw SerDeException | |
---|---|
Object |
ThriftByteStreamTypedSerDe.deserialize(org.apache.hadoop.io.Writable field)
|
Object |
ThriftDeserializer.deserialize(org.apache.hadoop.io.Writable field)
|
ObjectInspector |
ThriftDeserializer.getObjectInspector()
|
void |
ThriftByteStreamTypedSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
void |
ThriftDeserializer.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
Constructors in org.apache.hadoop.hive.serde2.thrift that throw SerDeException | |
---|---|
ThriftByteStreamTypedSerDe(Type objectType,
org.apache.thrift.protocol.TProtocolFactory inFactory,
org.apache.thrift.protocol.TProtocolFactory outFactory)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |