@Internal public interface PulsarSchemaFactory<T>
SchemaType
. We add this factory because of pulsar
don't provide a serializable schema and we can't create it directly from SchemaInfo
. So
we have to implement this creation logic.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.
|
org.apache.pulsar.common.schema.SchemaType type()
org.apache.pulsar.client.api.Schema<T> createSchema(org.apache.pulsar.common.schema.SchemaInfo info)
TypeInformation<T> createTypeInfo(org.apache.pulsar.common.schema.SchemaInfo info)
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.