Uses of Interface
org.apache.pulsar.broker.service.Topic.PublishContext
Packages that use Topic.PublishContext
Package
Description
Pulsar broker interceptor.
-
Uses of Topic.PublishContext in org.apache.pulsar.broker.intercept
Methods in org.apache.pulsar.broker.intercept with parameters of type Topic.PublishContextModifier and TypeMethodDescriptiondefault void
BrokerInterceptor.messageProduced
(ServerCnx cnx, Producer producer, long startTimeNs, long ledgerId, long entryId, Topic.PublishContext publishContext) Intercept after a message is produced.void
BrokerInterceptors.messageProduced
(ServerCnx cnx, Producer producer, long startTimeNs, long ledgerId, long entryId, Topic.PublishContext publishContext) void
BrokerInterceptorWithClassLoader.messageProduced
(ServerCnx cnx, Producer producer, long startTimeNs, long ledgerId, long entryId, Topic.PublishContext publishContext) default void
BrokerInterceptor.onMessagePublish
(Producer producer, io.netty.buffer.ByteBuf headersAndPayload, Topic.PublishContext publishContext) Intercept message when broker receive a send request.void
BrokerInterceptors.onMessagePublish
(Producer producer, io.netty.buffer.ByteBuf headersAndPayload, Topic.PublishContext publishContext) void
BrokerInterceptorWithClassLoader.onMessagePublish
(Producer producer, io.netty.buffer.ByteBuf headersAndPayload, Topic.PublishContext publishContext) -
Uses of Topic.PublishContext in org.apache.pulsar.broker.rest
Classes in org.apache.pulsar.broker.rest that implement Topic.PublishContextModifier and TypeClassDescriptionclass
PublishContext implementation for REST message publishing. -
Uses of Topic.PublishContext in org.apache.pulsar.broker.service
Methods in org.apache.pulsar.broker.service with parameters of type Topic.PublishContextModifier and TypeMethodDescriptionprotected boolean
AbstractTopic.isExceedMaximumMessageSize
(int size, Topic.PublishContext publishContext) void
Topic.publishMessage
(io.netty.buffer.ByteBuf headersAndPayload, Topic.PublishContext callback) void
Topic.publishTxnMessage
(org.apache.pulsar.client.api.transaction.TxnID txnID, io.netty.buffer.ByteBuf headersAndPayload, Topic.PublishContext publishContext) Publish Transaction message to this Topic's TransactionBuffer. -
Uses of Topic.PublishContext in org.apache.pulsar.broker.service.nonpersistent
Methods in org.apache.pulsar.broker.service.nonpersistent with parameters of type Topic.PublishContextModifier and TypeMethodDescriptionvoid
NonPersistentTopic.publishMessage
(io.netty.buffer.ByteBuf data, Topic.PublishContext callback) void
NonPersistentTopic.publishTxnMessage
(org.apache.pulsar.client.api.transaction.TxnID txnID, io.netty.buffer.ByteBuf headersAndPayload, Topic.PublishContext publishContext) -
Uses of Topic.PublishContext in org.apache.pulsar.broker.service.persistent
Classes in org.apache.pulsar.broker.service.persistent that implement Topic.PublishContextModifier and TypeClassDescriptionclass
Encapsulate all the logic of replicated subscriptions tracking for a given topic.Methods in org.apache.pulsar.broker.service.persistent with parameters of type Topic.PublishContextModifier and TypeMethodDescriptionMessageDeduplication.isDuplicate
(Topic.PublishContext publishContext, io.netty.buffer.ByteBuf headersAndPayload) Assess whether the message was already stored in the topic.void
PersistentTopic.publishMessage
(io.netty.buffer.ByteBuf headersAndPayload, Topic.PublishContext publishContext) void
PersistentTopic.publishTxnMessage
(org.apache.pulsar.client.api.transaction.TxnID txnID, io.netty.buffer.ByteBuf headersAndPayload, Topic.PublishContext publishContext) void
MessageDeduplication.recordMessagePersisted
(Topic.PublishContext publishContext, PositionImpl position) Call this method whenever a message is persisted to get the chance to trigger a snapshot.