|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of SerDeException in org.apache.hadoop.hive.metastore |
---|
Methods in org.apache.hadoop.hive.metastore that throw SerDeException | |
---|---|
static List<FieldSchema> |
MetaStoreUtils.getFieldsFromDeserializer(String tableName,
Deserializer deserializer)
|
Uses of SerDeException in org.apache.hadoop.hive.ql.exec |
---|
Methods in org.apache.hadoop.hive.ql.exec that throw SerDeException | |
---|---|
void |
MapJoinOperator.generateMapMetaData()
|
Uses of SerDeException in org.apache.hadoop.hive.ql.io |
---|
Methods in org.apache.hadoop.hive.ql.io that throw SerDeException | |
---|---|
void |
TestRCFile.fullyReadTest(org.apache.hadoop.fs.FileSystem fs,
int count,
org.apache.hadoop.fs.Path file)
|
void |
TestRCFile.testExplicitRCFileHeader()
|
void |
TestRCFile.testNonExplicitRCFileHeader()
|
void |
TestRCFile.testRCFileHeader(char[] expected,
org.apache.hadoop.conf.Configuration conf)
|
void |
TestRCFile.testReadCorruptFile()
|
void |
TestRCFile.testSimpleReadAndWrite()
|
void |
TestRCFile.testWriteAndFullyRead()
|
void |
TestRCFile.testWriteAndPartialRead()
|
Uses of SerDeException in org.apache.hadoop.hive.serde2 |
---|
Methods in org.apache.hadoop.hive.serde2 that throw SerDeException | |
---|---|
Object |
TestSerDe.deserialize(org.apache.hadoop.io.Writable field)
|
Object |
TypedSerDe.deserialize(org.apache.hadoop.io.Writable blob)
|
Object |
RegexSerDe.deserialize(org.apache.hadoop.io.Writable blob)
|
Object |
NullStructSerDe.deserialize(org.apache.hadoop.io.Writable blob)
|
Object |
MetadataTypedColumnsetSerDe.deserialize(org.apache.hadoop.io.Writable field)
|
Object |
Deserializer.deserialize(org.apache.hadoop.io.Writable blob)
Deserialize an object out of a Writable blob. |
Object |
DelimitedJSONSerDe.deserialize(org.apache.hadoop.io.Writable field)
Not implemented. |
Object |
ByteStreamTypedSerDe.deserialize(org.apache.hadoop.io.Writable field)
|
ObjectInspector |
TestSerDe.getObjectInspector()
|
ObjectInspector |
TypedSerDe.getObjectInspector()
|
ObjectInspector |
RegexSerDe.getObjectInspector()
|
ObjectInspector |
NullStructSerDe.getObjectInspector()
|
ObjectInspector |
MetadataTypedColumnsetSerDe.getObjectInspector()
|
ObjectInspector |
Deserializer.getObjectInspector()
Get the object inspector that can be used to navigate through the internal structure of the Object returned from deserialize(...). |
void |
TestSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
void |
TypedSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
void |
Serializer.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Initialize the HiveSerializer. |
void |
RegexSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
|
void |
NullStructSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
|
void |
MetadataTypedColumnsetSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
void |
Deserializer.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
Initialize the HiveDeserializer. |
static Deserializer |
SerDeUtils.lookupDeserializer(String name)
|
org.apache.hadoop.io.Writable |
TestSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
org.apache.hadoop.io.Writable |
TypedSerDe.serialize(Object obj,
ObjectInspector objInspector)
|
org.apache.hadoop.io.Writable |
Serializer.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object by navigating inside the Object with the ObjectInspector. |
org.apache.hadoop.io.Writable |
RegexSerDe.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)
|
protected void |
DelimitedJSONSerDe.serializeField(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
LazySimpleSerDe.SerDeParameters serdeParams)
|
void |
TestSerdeWithFieldComments.testFieldComments()
|
Constructors in org.apache.hadoop.hive.serde2 that throw SerDeException | |
---|---|
ByteStreamTypedSerDe(Type objectType)
|
|
DelimitedJSONSerDe()
|
|
MetadataTypedColumnsetSerDe()
|
|
TestSerDe()
|
|
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 | |
---|---|
void |
TestAvroSerde.badSchemaURLProvidedReturnsErrorSchema()
|
void |
TestAvroSerde.bothPropertiesSetToNoneReturnsErrorSchema()
|
void |
TestAvroDeserializer.canDeserializeArrays()
|
void |
TestAvroDeserializer.canDeserializeBytes()
|
void |
TestAvroDeserializer.canDeserializeEnums()
|
void |
TestAvroDeserializer.canDeserializeFixed()
|
void |
TestAvroDeserializer.canDeserializeMapsWithPrimitiveKeys()
|
void |
TestAvroDeserializer.canDeserializeMapWithNullablePrimitiveValues()
|
void |
TestAvroDeserializer.canDeserializeNullableTypes()
|
void |
TestAvroDeserializer.canDeserializeRecords()
|
void |
TestAvroDeserializer.canDeserializeUnions()
|
void |
TestAvroDeserializer.canDeserializeVoidType()
|
void |
TestAvroObjectInspectorGenerator.canHandleArrays()
|
void |
TestAvroObjectInspectorGenerator.canHandleBytes()
|
void |
TestAvroObjectInspectorGenerator.canHandleEnums()
|
void |
TestAvroObjectInspectorGenerator.canHandleFixed()
|
void |
TestAvroObjectInspectorGenerator.canHandleMapsWithPrimitiveValueTypes()
|
void |
TestAvroObjectInspectorGenerator.canHandleRecords()
|
void |
TestAvroObjectInspectorGenerator.canHandleUnions()
|
void |
TestAvroSerializer.canSerializeBooleans()
|
void |
TestAvroSerializer.canSerializeBytes()
|
void |
TestAvroSerializer.canSerializeDoubles()
|
void |
TestAvroSerializer.canSerializeEnums()
|
void |
TestAvroSerializer.canSerializeFixed()
|
void |
TestAvroSerializer.canSerializeFloats()
|
void |
TestAvroSerializer.canSerializeInts()
|
void |
TestAvroSerializer.canSerializeLists()
|
void |
TestAvroSerializer.canSerializeMaps()
|
void |
TestAvroSerializer.canSerializeMapsWithNullablePrimitiveValues()
|
void |
TestAvroSerializer.canSerializeNullableTypes()
|
void |
TestAvroSerializer.canSerializeStrings()
|
void |
TestAvroSerializer.canSerializeStructs()
|
void |
TestAvroSerializer.canSerializeUnions()
|
void |
TestAvroObjectInspectorGenerator.convertsMapsWithNullablePrimitiveTypes()
|
void |
TestAvroObjectInspectorGenerator.convertsNullableTypes()
|
Object |
AvroSerDe.deserialize(org.apache.hadoop.io.Writable writable)
|
void |
TestAvroSerde.emptySchemaProvidedReturnsErrorSchema()
|
void |
TestAvroSerde.emptySchemaURLProvidedReturnsErrorSchema()
|
ObjectInspector |
AvroSerDe.getObjectInspector()
|
void |
TestAvroSerde.gibberishSchemaProvidedReturnsErrorSchema()
|
void |
AvroSerDe.initialize(org.apache.hadoop.conf.Configuration configuration,
Properties properties)
|
void |
TestAvroSerde.initializeDoesNotReuseSchemasFromConf()
|
void |
TestAvroSerde.noSchemaProvidedReturnsErrorSchema()
|
void |
TestAvroObjectInspectorGenerator.objectInspectorsAreCached()
|
void |
TestAvroObjectInspectorGenerator.primitiveTypesWorkCorrectly()
|
void |
TestSchemaReEncoder.schemasCanAddFields()
|
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 |
LazyBinaryColumnarSerDe.initialize(org.apache.hadoop.conf.Configuration conf,
Properties tbl)
|
void |
ColumnarSerDe.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
Initialize the SerDe given the parameters. |
protected void |
ColumnarSerDeBase.initialize(int size)
|
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. |
void |
TestLazyBinaryColumnarSerDe.testLazyBinaryColumnarSerDeWithEmptyBinary()
|
void |
TestLazyBinaryColumnarSerDe.testSerDe()
|
void |
TestLazyBinaryColumnarSerDe.testSerDeEmpties()
|
void |
TestLazyBinaryColumnarSerDe.testSerDeInnerNulls()
|
void |
TestLazyBinaryColumnarSerDe.testSerDeOuterNulls()
|
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 |
DynamicSerDeTypeString.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. |
Map<Object,Object> |
DynamicSerDeTypeMap.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
ArrayList<Object> |
DynamicSerDeTypeList.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypei64.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypei32.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypei16.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypeDouble.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypedef.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypeByte.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeTypeBool.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
abstract Object |
DynamicSerDeTypeBase.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeStructBase.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
Object |
DynamicSerDeFieldList.deserialize(Object reuse,
org.apache.thrift.protocol.TProtocol iprot)
|
String |
DynamicSerDeTypeString.deserialize(org.apache.thrift.protocol.TProtocol iprot)
|
Byte |
DynamicSerDeTypeByte.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 |
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)
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.lazy |
---|
Methods in org.apache.hadoop.hive.serde2.lazy that throw SerDeException | |
---|---|
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)
|
org.apache.hadoop.io.Writable |
LazySimpleSerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize a row of data. |
protected void |
LazySimpleSerDe.serializeField(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
LazySimpleSerDe.SerDeParameters serdeParams)
|
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. |
org.apache.hadoop.io.Writable |
LazyBinarySerDe.serialize(Object obj,
ObjectInspector objInspector)
Serialize an object to a byte buffer in a binary compact way. |
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 | |
---|---|
void |
TestSimpleMapEqualComparer.testCompatibleType()
|
void |
TestCrossMapEqualComparer.testCompatibleType()
|
void |
TestSimpleMapEqualComparer.testIncompatibleType()
|
void |
TestCrossMapEqualComparer.testIncompatibleType()
|
Uses of SerDeException in org.apache.hadoop.hive.serde2.thrift |
---|
Methods in org.apache.hadoop.hive.serde2.thrift that throw SerDeException | |
---|---|
Object |
ThriftDeserializer.deserialize(org.apache.hadoop.io.Writable field)
|
Object |
ThriftByteStreamTypedSerDe.deserialize(org.apache.hadoop.io.Writable field)
|
ObjectInspector |
ThriftDeserializer.getObjectInspector()
|
void |
ThriftDeserializer.initialize(org.apache.hadoop.conf.Configuration job,
Properties tbl)
|
void |
ThriftByteStreamTypedSerDe.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 |