public class PrimitiveSchemaFactory<T> extends Object implements PulsarSchemaFactory<T>
Constructor and Description |
---|
PrimitiveSchemaFactory(org.apache.pulsar.client.api.Schema<T> schema,
TypeInformation<T> typeInformation) |
PrimitiveSchemaFactory(org.apache.pulsar.common.schema.SchemaType type,
org.apache.pulsar.client.api.Schema<T> schema,
TypeInformation<T> typeInformation) |
Modifier and Type | Method and Description |
---|---|
org.apache.pulsar.client.api.Schema<T> |
createSchema(org.apache.pulsar.common.schema.SchemaInfo info)
Create the schema by the given info.
|
TypeInformation<T> |
createTypeInfo(org.apache.pulsar.common.schema.SchemaInfo info)
Create the flink type information by the given schema info.
|
org.apache.pulsar.common.schema.SchemaType |
type()
The supported schema type for this factory.
|
public PrimitiveSchemaFactory(org.apache.pulsar.client.api.Schema<T> schema, TypeInformation<T> typeInformation)
public PrimitiveSchemaFactory(org.apache.pulsar.common.schema.SchemaType type, org.apache.pulsar.client.api.Schema<T> schema, TypeInformation<T> typeInformation)
public org.apache.pulsar.common.schema.SchemaType type()
PulsarSchemaFactory
type
in interface PulsarSchemaFactory<T>
public org.apache.pulsar.client.api.Schema<T> createSchema(org.apache.pulsar.common.schema.SchemaInfo info)
PulsarSchemaFactory
createSchema
in interface PulsarSchemaFactory<T>
public TypeInformation<T> createTypeInfo(org.apache.pulsar.common.schema.SchemaInfo info)
PulsarSchemaFactory
createTypeInfo
in interface PulsarSchemaFactory<T>
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.