Modifier and Type | Method and Description |
---|---|
HiveStoragePredicateHandler.DecomposedPredicate |
AccumuloStorageHandler.decomposePredicate(org.apache.hadoop.mapred.JobConf conf,
Deserializer deserializer,
ExprNodeDesc desc) |
Modifier and Type | Class and Description |
---|---|
class |
AccumuloSerDe
Deserialization from Accumulo to LazyAccumuloRow for Hive.
|
Modifier and Type | Class and Description |
---|---|
class |
MultiDelimitSerDe
This SerDe allows user to use multiple characters as the field delimiter for a table.
|
class |
TypedBytesSerDe
TypedBytesSerDe uses typed bytes to serialize/deserialize.
|
Modifier and Type | Class and Description |
---|---|
class |
S3LogDeserializer
S3LogDeserializer.
|
Modifier and Type | Class and Description |
---|---|
class |
HBaseSerDe
HBaseSerDe can be used to serialize object into an HBase table and
deserialize objects from an HBase table.
|
Modifier and Type | Method and Description |
---|---|
HiveStoragePredicateHandler.DecomposedPredicate |
HBaseStorageHandler.decomposePredicate(org.apache.hadoop.mapred.JobConf jobConf,
Deserializer deserializer,
ExprNodeDesc predicate) |
HiveStoragePredicateHandler.DecomposedPredicate |
AbstractHBaseKeyFactory.decomposePredicate(org.apache.hadoop.mapred.JobConf jobConf,
Deserializer deserializer,
ExprNodeDesc predicate) |
Modifier and Type | Method and Description |
---|---|
static Deserializer |
MetaStoreUtils.getDeserializer(org.apache.hadoop.conf.Configuration conf,
Partition part,
Table table)
getDeserializer
Get the Deserializer for a partition.
|
static Deserializer |
MetaStoreUtils.getDeserializer(org.apache.hadoop.conf.Configuration conf,
Table table,
boolean skipConfError)
getDeserializer
Get the Deserializer for a table.
|
Modifier and Type | Method and Description |
---|---|
static Class<? extends Deserializer> |
MetaStoreUtils.getDeserializerClass(org.apache.hadoop.conf.Configuration conf,
Table table) |
Modifier and Type | Method and Description |
---|---|
static List<FieldSchema> |
MetaStoreUtils.getFieldsFromDeserializer(String tableName,
Deserializer deserializer) |
Modifier and Type | Method and Description |
---|---|
Deserializer |
MapOperator.getCurrentDeserializer() |
Modifier and Type | Method and Description |
---|---|
static Object[] |
MapOperator.populateVirtualColumnValues(ExecMapperContext ctx,
List<VirtualColumn> vcs,
Object[] vcValues,
Deserializer deserializer) |
Constructor and Description |
---|
KeyValueInputMerger(List<org.apache.tez.runtime.library.api.KeyValueReader> multiMRInputs,
Deserializer deserializer,
ObjectInspector[] inputObjInspectors,
List<String> sortCols) |
Modifier and Type | Class and Description |
---|---|
class |
VectorizedColumnarSerDe
VectorizedColumnarSerDe is used by Vectorized query execution engine
for columnar based storage supported by RCFile.
|
Constructor and Description |
---|
VectorizedRowBatchCtx(StructObjectInspector rawRowOI,
StructObjectInspector rowOI,
Deserializer deserializer,
Map<String,Object> partitionValues,
Map<String,PrimitiveObjectInspector.PrimitiveCategory> partitionTypes)
Constructor for VectorizedRowBatchCtx
|
Modifier and Type | Class and Description |
---|---|
class |
OrcSerde
A serde class for ORC.
|
class |
VectorizedOrcSerde
A serde class for ORC.
|
Modifier and Type | Class and Description |
---|---|
class |
ParquetHiveSerDe
A ParquetHiveSerDe for Hive (with the deprecated package mapred)
|
Modifier and Type | Method and Description |
---|---|
Deserializer |
Table.getDeserializer() |
Deserializer |
Partition.getDeserializer() |
Deserializer |
Table.getDeserializer(boolean skipConfError) |
Deserializer |
Table.getDeserializerFromMetaStore(boolean skipConfError) |
Modifier and Type | Method and Description |
---|---|
Class<? extends Deserializer> |
Table.getDeserializerClass() |
Modifier and Type | Method and Description |
---|---|
HiveStoragePredicateHandler.DecomposedPredicate |
HiveStoragePredicateHandler.decomposePredicate(org.apache.hadoop.mapred.JobConf jobConf,
Deserializer deserializer,
ExprNodeDesc predicate)
Gives the storage handler a chance to decompose a predicate.
|
static List<FieldSchema> |
Hive.getFieldsFromDeserializer(String name,
Deserializer serde) |
Modifier and Type | Method and Description |
---|---|
Deserializer |
TableDesc.getDeserializer() |
Deserializer |
TableDesc.getDeserializer(org.apache.hadoop.conf.Configuration conf)
Return a deserializer object corresponding to the tableDesc.
|
Deserializer |
PartitionDesc.getDeserializer(org.apache.hadoop.conf.Configuration conf)
Return a deserializer object corresponding to the partitionDesc.
|
Deserializer |
TableDesc.getDeserializer(org.apache.hadoop.conf.Configuration conf,
boolean ignoreError) |
Modifier and Type | Method and Description |
---|---|
Class<? extends Deserializer> |
TableDesc.getDeserializerClass() |
Modifier and Type | Method and Description |
---|---|
static TableDesc |
PlanUtils.getTableDesc(Class<? extends Deserializer> serdeClass,
String separatorCode,
String columns)
Generate the table descriptor of given serde with the separatorCode and
column names (comma separated string).
|
static TableDesc |
PlanUtils.getTableDesc(Class<? extends Deserializer> serdeClass,
String separatorCode,
String columns,
boolean lastColumnTakesRestOfTheLine)
Generate the table descriptor of the serde specified with the separatorCode
and column names (comma separated string), and whether the last column
should take the rest of the line.
|
static TableDesc |
PlanUtils.getTableDesc(Class<? extends Deserializer> serdeClass,
String separatorCode,
String columns,
String columnTypes,
boolean lastColumnTakesRestOfTheLine) |
static TableDesc |
PlanUtils.getTableDesc(Class<? extends Deserializer> serdeClass,
String separatorCode,
String columns,
String columnTypes,
boolean lastColumnTakesRestOfTheLine,
boolean useDelimitedJSON) |
static TableDesc |
PlanUtils.getTableDesc(Class<? extends Deserializer> serdeClass,
String separatorCode,
String columns,
String columnTypes,
boolean lastColumnTakesRestOfTheLine,
boolean useDelimitedJSON,
String fileFormat) |
Modifier and Type | Interface and Description |
---|---|
interface |
SerDe
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDeserializer
Abstract class for implementing Deserializer.
|
class |
AbstractEncodingAwareSerDe
AbstractEncodingAwareSerDe aware the encoding from table properties,
transform data from specified charset to UTF-8 during serialize, and
transform data from UTF-8 to specified charset during deserialize.
|
class |
AbstractSerDe
Abstract class for implementing SerDe.
|
class |
ByteStreamTypedSerDe
ByteStreamTypedSerDe.
|
class |
DelimitedJSONSerDe
DelimitedJSONSerDe.
|
class |
MetadataTypedColumnsetSerDe
MetadataTypedColumnsetSerDe.
|
class |
NullStructSerDe
Placeholder SerDe for cases where neither serialization nor deserialization is needed
|
class |
OpenCSVSerde
OpenCSVSerde use opencsv to deserialize CSV format.
|
class |
RegexSerDe
RegexSerDe uses regular expression (regex) to deserialize data.
|
class |
TypedSerDe
TypedSerDe.
|
Modifier and Type | Method and Description |
---|---|
static void |
SerDeUtils.initializeSerDe(Deserializer deserializer,
org.apache.hadoop.conf.Configuration conf,
Properties tblProps,
Properties partProps)
Initializes a SerDe.
|
static void |
SerDeUtils.initializeSerDeWithoutErrorCheck(Deserializer deserializer,
org.apache.hadoop.conf.Configuration conf,
Properties tblProps,
Properties partProps)
Initializes a SerDe.
|
Modifier and Type | Class and Description |
---|---|
class |
AvroSerDe
Read or write Avro data from Hive.
|
Modifier and Type | Class and Description |
---|---|
class |
BinarySortableSerDe
BinarySortableSerDe can be used to write data in a way that the data can be
compared byte-by-byte with the same order.
|
Modifier and Type | Class and Description |
---|---|
class |
ColumnarSerDe
ColumnarSerDe is used for columnar based storage supported by RCFile.
|
class |
ColumnarSerDeBase |
class |
LazyBinaryColumnarSerDe
LazyBinaryColumnarSerDe.
|
Modifier and Type | Class and Description |
---|---|
class |
DynamicSerDe
DynamicSerDe.
|
Modifier and Type | Class and Description |
---|---|
class |
LazySimpleSerDe
LazySimpleSerDe can be used to read the same data format as
MetadataTypedColumnsetSerDe and TCTLSeparatedProtocol.
|
Modifier and Type | Class and Description |
---|---|
class |
LazyBinarySerDe
The LazyBinarySerDe class combines the lazy property of LazySimpleSerDe class
and the binary property of BinarySortable class.
|
Modifier and Type | Class and Description |
---|---|
class |
ThriftByteStreamTypedSerDe
ThriftByteStreamTypedSerDe.
|
class |
ThriftDeserializer
ThriftDeserializer.
|
Modifier and Type | Class and Description |
---|---|
class |
HCatRecordSerDe
SerDe class for serializing to and from HCatRecord
|
class |
JsonSerDe |
Copyright © 2017 The Apache Software Foundation. All rights reserved.