Package | Description |
---|---|
org.apache.flink.connector.pulsar.sink | |
org.apache.flink.connector.pulsar.sink.writer | |
org.apache.flink.connector.pulsar.sink.writer.router |
Modifier and Type | Method and Description |
---|---|
PulsarSinkBuilder<IN> |
PulsarSinkBuilder.setTopicRouter(TopicRouter<IN> topicRouter)
Use a custom topic router instead predefine topic routing.
|
Constructor and Description |
---|
PulsarWriter(SinkConfiguration sinkConfiguration,
PulsarSerializationSchema<IN> serializationSchema,
TopicMetadataListener metadataListener,
TopicRouter<IN> topicRouter,
MessageDelayer<IN> messageDelayer,
Sink.InitContext initContext)
Constructor creating a Pulsar writer.
|
Modifier and Type | Class and Description |
---|---|
class |
KeyHashTopicRouter<IN>
If you choose the
TopicRoutingMode.MESSAGE_KEY_HASH policy, we would use this
implementation. |
class |
RoundRobinTopicRouter<IN>
If you choose the
TopicRoutingMode.ROUND_ROBIN policy, we would use this implementation. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.