Class Commands

java.lang.Object
org.apache.pulsar.common.protocol.Commands

public class Commands extends Object
  • Field Details

  • Constructor Details

    • Commands

      public Commands()
  • Method Details

    • newConnect

      public static io.netty.buffer.ByteBuf newConnect(String authMethodName, String authData, String libVersion)
    • newConnect

      public static io.netty.buffer.ByteBuf newConnect(String authMethodName, String authData, String libVersion, String targetBroker)
    • newConnect

      public static io.netty.buffer.ByteBuf newConnect(String authMethodName, String authData, String libVersion, String targetBroker, String originalPrincipal, String clientAuthData, String clientAuthMethod)
    • newConnect

      public static io.netty.buffer.ByteBuf newConnect(String authMethodName, String authData, int protocolVersion, String libVersion, String targetBroker, String originalPrincipal, String originalAuthData, String originalAuthMethod)
    • newConnect

      public static io.netty.buffer.ByteBuf newConnect(String authMethodName, AuthData authData, int protocolVersion, String libVersion, String targetBroker, String originalPrincipal, AuthData originalAuthData, String originalAuthMethod)
    • newConnect

      public static io.netty.buffer.ByteBuf newConnect(String authMethodName, AuthData authData, int protocolVersion, String libVersion, String targetBroker, String originalPrincipal, AuthData originalAuthData, String originalAuthMethod, String proxyVersion)
    • newConnected

      public static io.netty.buffer.ByteBuf newConnected(int clientProtocoVersion, boolean supportsTopicWatchers)
    • newConnectedCommand

      public static BaseCommand newConnectedCommand(int clientProtocolVersion, int maxMessageSize, boolean supportsTopicWatchers)
    • newConnected

      public static io.netty.buffer.ByteBuf newConnected(int clientProtocolVersion, int maxMessageSize, boolean supportsTopicWatchers)
    • newAuthChallenge

      public static io.netty.buffer.ByteBuf newAuthChallenge(String authMethod, AuthData brokerData, int clientProtocolVersion)
    • newAuthResponse

      public static io.netty.buffer.ByteBuf newAuthResponse(String authMethod, AuthData clientData, int clientProtocolVersion, String clientVersion)
    • newSuccessCommand

      public static BaseCommand newSuccessCommand(long requestId)
    • newSuccess

      public static io.netty.buffer.ByteBuf newSuccess(long requestId)
    • newProducerSuccessCommand

      public static BaseCommand newProducerSuccessCommand(long requestId, String producerName, SchemaVersion schemaVersion)
    • newProducerSuccess

      public static io.netty.buffer.ByteBuf newProducerSuccess(long requestId, String producerName, SchemaVersion schemaVersion)
    • newProducerSuccessCommand

      public static BaseCommand newProducerSuccessCommand(long requestId, String producerName, long lastSequenceId, SchemaVersion schemaVersion, Optional<Long> topicEpoch, boolean isProducerReady)
    • newProducerSuccess

      public static io.netty.buffer.ByteBuf newProducerSuccess(long requestId, String producerName, long lastSequenceId, SchemaVersion schemaVersion, Optional<Long> topicEpoch, boolean isProducerReady)
    • newErrorCommand

      public static BaseCommand newErrorCommand(long requestId, ServerError serverError, String message)
    • newError

      public static io.netty.buffer.ByteBuf newError(long requestId, ServerError serverError, String message)
    • newSendReceiptCommand

      public static BaseCommand newSendReceiptCommand(long producerId, long sequenceId, long highestId, long ledgerId, long entryId)
    • newSendReceipt

      public static io.netty.buffer.ByteBuf newSendReceipt(long producerId, long sequenceId, long highestId, long ledgerId, long entryId)
    • newSendErrorCommand

      public static BaseCommand newSendErrorCommand(long producerId, long sequenceId, ServerError error, String errorMsg)
    • newSendError

      public static io.netty.buffer.ByteBuf newSendError(long producerId, long sequenceId, ServerError error, String errorMsg)
    • hasChecksum

      public static boolean hasChecksum(io.netty.buffer.ByteBuf buffer)
    • readChecksum

      public static int readChecksum(io.netty.buffer.ByteBuf buffer)
      Read the checksum and advance the reader index in the buffer.

      Note: This method assume the checksum presence was already verified before.

    • skipChecksumIfPresent

      public static void skipChecksumIfPresent(io.netty.buffer.ByteBuf buffer)
    • parseMessageMetadata

      public static MessageMetadata parseMessageMetadata(io.netty.buffer.ByteBuf buffer)
    • parseMessageMetadata

      public static void parseMessageMetadata(io.netty.buffer.ByteBuf buffer, MessageMetadata msgMetadata)
    • skipMessageMetadata

      public static void skipMessageMetadata(io.netty.buffer.ByteBuf buffer)
    • getEntryTimestamp

      public static long getEntryTimestamp(io.netty.buffer.ByteBuf headersAndPayloadWithBrokerEntryMetadata) throws IOException
      Throws:
      IOException
    • newMessageCommand

      public static BaseCommand newMessageCommand(long consumerId, long ledgerId, long entryId, int partition, int redeliveryCount, long[] ackSet, long consumerEpoch)
    • newMessage

      public static ByteBufPair newMessage(long consumerId, long ledgerId, long entryId, int partition, int redeliveryCount, io.netty.buffer.ByteBuf metadataAndPayload, long[] ackSet)
    • newSend

      public static ByteBufPair newSend(long producerId, long sequenceId, int numMessages, Commands.ChecksumType checksumType, long ledgerId, long entryId, MessageMetadata messageMetadata, io.netty.buffer.ByteBuf payload)
    • newSend

      public static ByteBufPair newSend(long producerId, long sequenceId, int numMessages, Commands.ChecksumType checksumType, MessageMetadata messageMetadata, io.netty.buffer.ByteBuf payload)
    • newSend

      public static ByteBufPair newSend(long producerId, long lowestSequenceId, long highestSequenceId, int numMessages, Commands.ChecksumType checksumType, MessageMetadata messageMetadata, io.netty.buffer.ByteBuf payload)
    • newSend

      public static ByteBufPair newSend(long producerId, long sequenceId, long highestSequenceId, int numMessages, long txnIdLeastBits, long txnIdMostBits, Commands.ChecksumType checksumType, long ledgerId, long entryId, MessageMetadata messageData, io.netty.buffer.ByteBuf payload)
    • newSubscribe

      public static io.netty.buffer.ByteBuf newSubscribe(String topic, String subscription, long consumerId, long requestId, CommandSubscribe.SubType subType, int priorityLevel, String consumerName, long resetStartMessageBackInSeconds)
    • newSubscribe

      public static io.netty.buffer.ByteBuf newSubscribe(String topic, String subscription, long consumerId, long requestId, CommandSubscribe.SubType subType, int priorityLevel, String consumerName, boolean isDurable, MessageIdData startMessageId, Map<String,String> metadata, boolean readCompacted, boolean isReplicated, CommandSubscribe.InitialPosition subscriptionInitialPosition, long startMessageRollbackDurationInSec, SchemaInfo schemaInfo, boolean createTopicIfDoesNotExist)
    • newSubscribe

      public static io.netty.buffer.ByteBuf newSubscribe(String topic, String subscription, long consumerId, long requestId, CommandSubscribe.SubType subType, int priorityLevel, String consumerName, boolean isDurable, MessageIdData startMessageId, Map<String,String> metadata, boolean readCompacted, boolean isReplicated, CommandSubscribe.InitialPosition subscriptionInitialPosition, long startMessageRollbackDurationInSec, SchemaInfo schemaInfo, boolean createTopicIfDoesNotExist, KeySharedPolicy keySharedPolicy, Map<String,String> subscriptionProperties, long consumerEpoch)
    • newTcClientConnectRequest

      public static io.netty.buffer.ByteBuf newTcClientConnectRequest(long tcId, long requestId)
    • newTcClientConnectResponse

      public static BaseCommand newTcClientConnectResponse(long requestId, ServerError error, String message)
    • newUnsubscribe

      public static io.netty.buffer.ByteBuf newUnsubscribe(long consumerId, long requestId, boolean force)
    • newActiveConsumerChange

      public static io.netty.buffer.ByteBuf newActiveConsumerChange(long consumerId, boolean isActive)
    • newSeek

      public static io.netty.buffer.ByteBuf newSeek(long consumerId, long requestId, long ledgerId, long entryId, long[] ackSet)
    • newSeek

      public static io.netty.buffer.ByteBuf newSeek(long consumerId, long requestId, long timestamp)
    • newCloseConsumer

      public static io.netty.buffer.ByteBuf newCloseConsumer(long consumerId, long requestId, String assignedBrokerUrl, String assignedBrokerUrlTls)
    • newReachedEndOfTopic

      public static io.netty.buffer.ByteBuf newReachedEndOfTopic(long consumerId)
    • newTopicMigrated

      public static io.netty.buffer.ByteBuf newTopicMigrated(CommandTopicMigrated.ResourceType type, long resourceId, String brokerUrl, String brokerUrlTls)
    • newCloseProducer

      public static io.netty.buffer.ByteBuf newCloseProducer(long producerId, long requestId)
    • newCloseProducer

      public static io.netty.buffer.ByteBuf newCloseProducer(long producerId, long requestId, String assignedBrokerUrl, String assignedBrokerUrlTls)
    • newProducer

      public static io.netty.buffer.ByteBuf newProducer(String topic, long producerId, long requestId, String producerName, Map<String,String> metadata, boolean isTxnEnabled)
    • newProducer

      public static io.netty.buffer.ByteBuf newProducer(String topic, long producerId, long requestId, String producerName, boolean encrypted, Map<String,String> metadata, boolean isTxnEnabled)
    • getSchemaType

      public static SchemaType getSchemaType(Schema.Type type)
    • newProducer

      public static io.netty.buffer.ByteBuf newProducer(String topic, long producerId, long requestId, String producerName, boolean encrypted, Map<String,String> metadata, SchemaInfo schemaInfo, long epoch, boolean userProvidedProducerName, ProducerAccessMode accessMode, Optional<Long> topicEpoch, boolean isTxnEnabled)
    • newProducer

      public static io.netty.buffer.ByteBuf newProducer(String topic, long producerId, long requestId, String producerName, boolean encrypted, Map<String,String> metadata, SchemaInfo schemaInfo, long epoch, boolean userProvidedProducerName, ProducerAccessMode accessMode, Optional<Long> topicEpoch, boolean isTxnEnabled, String initialSubscriptionName)
    • newPartitionMetadataResponseCommand

      public static BaseCommand newPartitionMetadataResponseCommand(ServerError error, String errorMsg, long requestId)
    • newPartitionMetadataResponse

      public static io.netty.buffer.ByteBuf newPartitionMetadataResponse(ServerError error, String errorMsg, long requestId)
    • newPartitionMetadataRequest

      public static io.netty.buffer.ByteBuf newPartitionMetadataRequest(String topic, long requestId)
    • newPartitionMetadataResponseCommand

      public static BaseCommand newPartitionMetadataResponseCommand(int partitions, long requestId)
    • newPartitionMetadataResponse

      public static io.netty.buffer.ByteBuf newPartitionMetadataResponse(int partitions, long requestId)
    • newLookup

      public static io.netty.buffer.ByteBuf newLookup(String topic, boolean authoritative, long requestId)
    • newLookup

      public static io.netty.buffer.ByteBuf newLookup(String topic, String listenerName, boolean authoritative, long requestId)
    • newLookupResponseCommand

      public static BaseCommand newLookupResponseCommand(String brokerServiceUrl, String brokerServiceUrlTls, boolean authoritative, CommandLookupTopicResponse.LookupType lookupType, long requestId, boolean proxyThroughServiceUrl)
    • newLookupResponse

      public static io.netty.buffer.ByteBuf newLookupResponse(String brokerServiceUrl, String brokerServiceUrlTls, boolean authoritative, CommandLookupTopicResponse.LookupType lookupType, long requestId, boolean proxyThroughServiceUrl)
    • newLookupErrorResponseCommand

      public static BaseCommand newLookupErrorResponseCommand(ServerError error, String errorMsg, long requestId)
    • newLookupErrorResponse

      public static io.netty.buffer.ByteBuf newLookupErrorResponse(ServerError error, String errorMsg, long requestId)
    • newMultiTransactionMessageAck

      public static io.netty.buffer.ByteBuf newMultiTransactionMessageAck(long consumerId, TxnID txnID, List<org.apache.commons.lang3.tuple.Triple<Long,Long,ConcurrentBitSetRecyclable>> entries)
    • newMultiMessageAck

      public static io.netty.buffer.ByteBuf newMultiMessageAck(long consumerId, List<org.apache.commons.lang3.tuple.Triple<Long,Long,ConcurrentBitSetRecyclable>> entries, long requestId)
    • newAck

      public static io.netty.buffer.ByteBuf newAck(long consumerId, long ledgerId, long entryId, BitSetRecyclable ackSet, CommandAck.AckType ackType, CommandAck.ValidationError validationError, Map<String,Long> properties, long requestId)
    • newAck

      public static io.netty.buffer.ByteBuf newAck(long consumerId, long ledgerId, long entryId, BitSetRecyclable ackSet, CommandAck.AckType ackType, CommandAck.ValidationError validationError, Map<String,Long> properties, long txnIdLeastBits, long txnIdMostBits, long requestId, int batchSize)
    • newAck

      public static io.netty.buffer.ByteBuf newAck(long consumerId, List<MessageIdData> messageIds, CommandAck.AckType ackType, CommandAck.ValidationError validationError, Map<String,Long> properties, long txnIdLeastBits, long txnIdMostBits, long requestId)
    • newAck

      public static io.netty.buffer.ByteBuf newAck(long consumerId, long ledgerId, long entryId, BitSetRecyclable ackSet, CommandAck.AckType ackType, CommandAck.ValidationError validationError, Map<String,Long> properties, long txnIdLeastBits, long txnIdMostBits, long requestId)
    • newAckResponse

      public static io.netty.buffer.ByteBuf newAckResponse(long requestId, ServerError error, String errorMsg, long consumerId)
    • newFlow

      public static io.netty.buffer.ByteBuf newFlow(long consumerId, int messagePermits)
    • newRedeliverUnacknowledgedMessages

      public static io.netty.buffer.ByteBuf newRedeliverUnacknowledgedMessages(long consumerId, long consumerEpoch)
    • newRedeliverUnacknowledgedMessages

      public static io.netty.buffer.ByteBuf newRedeliverUnacknowledgedMessages(long consumerId, List<MessageIdData> messageIds)
    • newConsumerStatsResponse

      public static io.netty.buffer.ByteBuf newConsumerStatsResponse(ServerError serverError, String errMsg, long requestId)
    • newConsumerStatsResponseCommand

      public static BaseCommand newConsumerStatsResponseCommand(ServerError serverError, String errMsg, long requestId)
    • newGetTopicsOfNamespaceRequest

      public static io.netty.buffer.ByteBuf newGetTopicsOfNamespaceRequest(String namespace, long requestId, CommandGetTopicsOfNamespace.Mode mode, String topicsPattern, String topicsHash)
    • newGetTopicsOfNamespaceResponseCommand

      public static BaseCommand newGetTopicsOfNamespaceResponseCommand(List<String> topics, String topicsHash, boolean filtered, boolean changed, long requestId)
    • newGetTopicsOfNamespaceResponse

      public static io.netty.buffer.ByteBuf newGetTopicsOfNamespaceResponse(List<String> topics, String topicsHash, boolean filtered, boolean changed, long requestId)
    • newPong

      public static io.netty.buffer.ByteBuf newPong()
    • newGetLastMessageId

      public static io.netty.buffer.ByteBuf newGetLastMessageId(long consumerId, long requestId)
    • newGetLastMessageIdResponse

      public static io.netty.buffer.ByteBuf newGetLastMessageIdResponse(long requestId, long lastMessageLedgerId, long lastMessageEntryId, int lastMessagePartitionIdx, int lastMessageBatchIndex, long markDeletePositionLedgerId, long markDeletePositionEntryId)
    • newGetSchema

      public static io.netty.buffer.ByteBuf newGetSchema(long requestId, String topic, Optional<SchemaVersion> version)
    • newGetSchemaResponse

      public static io.netty.buffer.ByteBuf newGetSchemaResponse(long requestId, CommandGetSchemaResponse response)
    • newGetSchemaResponseCommand

      public static BaseCommand newGetSchemaResponseCommand(long requestId, SchemaInfo schemaInfo, SchemaVersion version)
    • newGetSchemaResponse

      public static io.netty.buffer.ByteBuf newGetSchemaResponse(long requestId, SchemaInfo schemaInfo, SchemaVersion version)
    • newGetSchemaResponseErrorCommand

      public static BaseCommand newGetSchemaResponseErrorCommand(long requestId, ServerError error, String errorMessage)
    • newGetSchemaResponseError

      public static io.netty.buffer.ByteBuf newGetSchemaResponseError(long requestId, ServerError error, String errorMessage)
    • newGetOrCreateSchema

      public static io.netty.buffer.ByteBuf newGetOrCreateSchema(long requestId, String topic, SchemaInfo schemaInfo)
    • newGetOrCreateSchemaResponseCommand

      public static BaseCommand newGetOrCreateSchemaResponseCommand(long requestId, SchemaVersion schemaVersion)
    • newGetOrCreateSchemaResponse

      public static io.netty.buffer.ByteBuf newGetOrCreateSchemaResponse(long requestId, SchemaVersion schemaVersion)
    • newGetOrCreateSchemaResponseErrorCommand

      public static BaseCommand newGetOrCreateSchemaResponseErrorCommand(long requestId, ServerError error, String errorMessage)
    • newGetOrCreateSchemaResponseError

      public static io.netty.buffer.ByteBuf newGetOrCreateSchemaResponseError(long requestId, ServerError error, String errorMessage)
    • newTxn

      public static io.netty.buffer.ByteBuf newTxn(long tcId, long requestId, long ttlSeconds)
    • newTxnResponse

      public static BaseCommand newTxnResponse(long requestId, long txnIdLeastBits, long txnIdMostBits)
    • newTxnResponse

      public static BaseCommand newTxnResponse(long requestId, long txnIdMostBits, ServerError error, String errorMsg)
    • newAddPartitionToTxn

      public static io.netty.buffer.ByteBuf newAddPartitionToTxn(long requestId, long txnIdLeastBits, long txnIdMostBits, List<String> partitions)
    • newAddPartitionToTxnResponse

      public static io.netty.buffer.ByteBuf newAddPartitionToTxnResponse(long requestId, long txnIdLeastBits, long txnIdMostBits)
    • newAddPartitionToTxnResponse

      public static io.netty.buffer.ByteBuf newAddPartitionToTxnResponse(long requestId, long txnIdLeastBits, long txnIdMostBits, ServerError error, String errorMsg)
    • newAddSubscriptionToTxn

      public static io.netty.buffer.ByteBuf newAddSubscriptionToTxn(long requestId, long txnIdLeastBits, long txnIdMostBits, List<Subscription> subscriptions)
    • newAddSubscriptionToTxnResponse

      public static io.netty.buffer.ByteBuf newAddSubscriptionToTxnResponse(long requestId, long txnIdLeastBits, long txnIdMostBits)
    • newAddSubscriptionToTxnResponse

      public static io.netty.buffer.ByteBuf newAddSubscriptionToTxnResponse(long requestId, long txnIdLeastBits, long txnIdMostBits, ServerError error, String errorMsg)
    • newEndTxn

      public static BaseCommand newEndTxn(long requestId, long txnIdLeastBits, long txnIdMostBits, TxnAction txnAction)
    • newEndTxnResponse

      public static BaseCommand newEndTxnResponse(long requestId, long txnIdLeastBits, long txnIdMostBits)
    • newEndTxnResponse

      public static BaseCommand newEndTxnResponse(long requestId, long txnIdLeastBits, long txnIdMostBits, ServerError error, String errorMsg)
    • newEndTxnOnPartition

      public static io.netty.buffer.ByteBuf newEndTxnOnPartition(long requestId, long txnIdLeastBits, long txnIdMostBits, String topic, TxnAction txnAction, long lowWaterMark)
    • newEndTxnOnPartitionResponse

      public static io.netty.buffer.ByteBuf newEndTxnOnPartitionResponse(long requestId, long txnIdLeastBits, long txnIdMostBits)
    • newEndTxnOnPartitionResponse

      public static io.netty.buffer.ByteBuf newEndTxnOnPartitionResponse(long requestId, ServerError error, String errorMsg, long txnIdLeastBits, long txnIdMostBits)
    • newEndTxnOnSubscription

      public static io.netty.buffer.ByteBuf newEndTxnOnSubscription(long requestId, long txnIdLeastBits, long txnIdMostBits, String topic, String subscription, TxnAction txnAction, long lowWaterMark)
    • newEndTxnOnSubscriptionResponse

      public static io.netty.buffer.ByteBuf newEndTxnOnSubscriptionResponse(long requestId, long txnIdLeastBits, long txnIdMostBits)
    • newEndTxnOnSubscriptionResponse

      public static io.netty.buffer.ByteBuf newEndTxnOnSubscriptionResponse(long requestId, long txnIdLeastBits, long txnIdMostBits, ServerError error, String errorMsg)
    • newWatchTopicList

      public static BaseCommand newWatchTopicList(long requestId, long watcherId, String namespace, String topicsPattern, String topicsHash)
    • newWatchTopicListSuccess

      public static BaseCommand newWatchTopicListSuccess(long requestId, long watcherId, String topicsHash, List<String> topics)
      Parameters:
      topics - topic names which are matching, the topic name contains the partition suffix.
    • newWatchTopicUpdate

      public static BaseCommand newWatchTopicUpdate(long watcherId, List<String> newTopics, List<String> deletedTopics, String topicsHash)
      Parameters:
      deletedTopics - topic names deleted(contains the partition suffix).
      newTopics - topics names added(contains the partition suffix).
    • newWatchTopicListClose

      public static BaseCommand newWatchTopicListClose(long watcherId, long requestId)
    • serializeWithSize

      public static io.netty.buffer.ByteBuf serializeWithSize(BaseCommand cmd)
    • addBrokerEntryMetadata

      public static io.netty.buffer.ByteBuf addBrokerEntryMetadata(io.netty.buffer.ByteBuf headerAndPayload, Set<BrokerEntryMetadataInterceptor> interceptors)
    • addBrokerEntryMetadata

      public static io.netty.buffer.ByteBuf addBrokerEntryMetadata(io.netty.buffer.ByteBuf headerAndPayload, Set<BrokerEntryMetadataInterceptor> brokerInterceptors, int numberOfMessages)
    • skipBrokerEntryMetadataIfExist

      public static io.netty.buffer.ByteBuf skipBrokerEntryMetadataIfExist(io.netty.buffer.ByteBuf headerAndPayloadWithBrokerEntryMetadata)
    • parseBrokerEntryMetadataIfExist

      public static BrokerEntryMetadata parseBrokerEntryMetadataIfExist(io.netty.buffer.ByteBuf headerAndPayloadWithBrokerEntryMetadata)
    • peekBrokerEntryMetadataIfExist

      public static BrokerEntryMetadata peekBrokerEntryMetadataIfExist(io.netty.buffer.ByteBuf headerAndPayloadWithBrokerEntryMetadata)
    • serializeMetadataAndPayload

      public static io.netty.buffer.ByteBuf serializeMetadataAndPayload(Commands.ChecksumType checksumType, MessageMetadata msgMetadata, io.netty.buffer.ByteBuf payload)
    • initBatchMessageMetadata

      public static long initBatchMessageMetadata(MessageMetadata messageMetadata, MessageMetadata builder)
    • serializeSingleMessageInBatchWithPayload

      public static io.netty.buffer.ByteBuf serializeSingleMessageInBatchWithPayload(SingleMessageMetadata singleMessageMetadata, io.netty.buffer.ByteBuf payload, io.netty.buffer.ByteBuf batchBuffer)
    • serializeSingleMessageInBatchWithPayload

      public static io.netty.buffer.ByteBuf serializeSingleMessageInBatchWithPayload(MessageMetadata msg, io.netty.buffer.ByteBuf payload, io.netty.buffer.ByteBuf batchBuffer)
    • deSerializeSingleMessageInBatch

      public static io.netty.buffer.ByteBuf deSerializeSingleMessageInBatch(io.netty.buffer.ByteBuf uncompressedPayload, SingleMessageMetadata singleMessageMetadata, int index, int batchSize) throws IOException
      Throws:
      IOException
    • serializeCommandMessageWithSize

      public static ByteBufPair serializeCommandMessageWithSize(BaseCommand cmd, io.netty.buffer.ByteBuf metadataAndPayload)
    • getNumberOfMessagesInBatch

      public static int getNumberOfMessagesInBatch(io.netty.buffer.ByteBuf metadataAndPayload, String subscription, long consumerId)
    • peekMessageMetadata

      public static MessageMetadata peekMessageMetadata(io.netty.buffer.ByteBuf metadataAndPayload, String subscription, long consumerId)
    • peekAndCopyMessageMetadata

      public static MessageMetadata peekAndCopyMessageMetadata(io.netty.buffer.ByteBuf metadataAndPayload, String subscription, long consumerId)
      Peek the message metadata from the buffer and return a deep copy of the metadata. If you want to hold multiple MessageMetadata instances from multiple buffers, you must call this method rather than peekMessageMetadata(ByteBuf, String, long), which returns a thread local reference, see LOCAL_MESSAGE_METADATA.
    • peekStickyKey

      public static byte[] peekStickyKey(io.netty.buffer.ByteBuf metadataAndPayload, String topic, String subscription)
    • getCurrentProtocolVersion

      public static int getCurrentProtocolVersion()
    • peerSupportsGetLastMessageId

      public static boolean peerSupportsGetLastMessageId(int peerVersion)
    • peerSupportsActiveConsumerListener

      public static boolean peerSupportsActiveConsumerListener(int peerVersion)
    • peerSupportsMultiMessageAcknowledgment

      public static boolean peerSupportsMultiMessageAcknowledgment(int peerVersion)
    • peerSupportJsonSchemaAvroFormat

      public static boolean peerSupportJsonSchemaAvroFormat(int peerVersion)
    • peerSupportsGetOrCreateSchema

      public static boolean peerSupportsGetOrCreateSchema(int peerVersion)
    • peerSupportsAckReceipt

      public static boolean peerSupportsAckReceipt(int peerVersion)
    • peerSupportsCarryAutoConsumeSchemaToBroker

      public static boolean peerSupportsCarryAutoConsumeSchemaToBroker(int peerVersion)
    • convertProducerAccessMode

      public static ProducerAccessMode convertProducerAccessMode(ProducerAccessMode accessMode)
    • peerSupportsBrokerMetadata

      public static boolean peerSupportsBrokerMetadata(int peerVersion)