@Deprecated public abstract class StructSchema<T> extends AbstractStructSchema<T>
Currently Pulsar supports 3 `Struct` types -
SchemaType.AVRO,
SchemaType.JSON,
and SchemaType.PROTOBUF.
| Modifier and Type | Field and Description |
|---|---|
protected org.apache.avro.Schema |
schema
Deprecated.
|
LOG, reader, schemaInfo, schemaInfoProvider, writerBOOL, BYTEBUFFER, BYTES, DATE, DOUBLE, FLOAT, INSTANT, INT16, INT32, INT64, INT8, LOCAL_DATE, LOCAL_DATE_TIME, LOCAL_TIME, STRING, TIME, TIMESTAMP| Modifier | Constructor and Description |
|---|---|
protected |
StructSchema(SchemaInfo schemaInfo)
Deprecated.
|
| Modifier and Type | Method and Description |
|---|---|
protected static org.apache.avro.Schema |
createAvroSchema(SchemaDefinition schemaDefinition)
Deprecated.
|
protected static org.apache.avro.Schema |
extractAvroSchema(SchemaDefinition schemaDefinition,
Class pojo)
Deprecated.
|
org.apache.avro.Schema |
getAvroSchema()
Deprecated.
|
protected static org.apache.avro.Schema |
parseAvroSchema(String schemaJson)
Deprecated.
|
static <T> SchemaInfo |
parseSchemaInfo(SchemaDefinition<T> schemaDefinition,
SchemaType schemaType)
Deprecated.
|
decode, decode, decode, decode, encode, getReader, getSchemaInfo, setReader, setSchemaInfoProvider, setWritercloneequals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitAUTO_CONSUME, AUTO_PRODUCE_BYTES, AUTO_PRODUCE_BYTES, AUTO, AVRO, AVRO, configureSchemaInfo, generic, getSchema, JSON, JSON, KeyValue, KeyValue, KeyValue, KeyValue, KV_BYTES, PROTOBUF_NATIVE, PROTOBUF_NATIVE, PROTOBUF, PROTOBUF, requireFetchingSchemaInfo, supportSchemaVersioning, validateprotected StructSchema(SchemaInfo schemaInfo)
public org.apache.avro.Schema getAvroSchema()
protected static org.apache.avro.Schema createAvroSchema(SchemaDefinition schemaDefinition)
protected static org.apache.avro.Schema extractAvroSchema(SchemaDefinition schemaDefinition, Class pojo)
protected static org.apache.avro.Schema parseAvroSchema(String schemaJson)
public static <T> SchemaInfo parseSchemaInfo(SchemaDefinition<T> schemaDefinition, SchemaType schemaType)
Copyright © 2017–2020 Apache Software Foundation. All rights reserved.