Uses of Class
org.apache.pulsar.common.api.proto.MessageIdData
Packages that use MessageIdData
Package
Description
Common protocol.
-
Uses of MessageIdData in org.apache.pulsar.common.api.proto
Methods in org.apache.pulsar.common.api.proto that return MessageIdDataModifier and TypeMethodDescriptionCommandAck.addMessageId()CommandRedeliverUnacknowledgedMessages.addMessageId()MessageIdData.clear()MessageIdData.clearAckSet()MessageIdData.clearBatchIndex()MessageIdData.clearBatchSize()MessageIdData.clearEntryId()MessageIdData.clearFirstChunkMessageId()MessageIdData.clearLedgerId()MessageIdData.clearPartition()MessageIdData.copyFrom(MessageIdData _other) CommandGetLastMessageIdResponse.getConsumerMarkDeletePosition()MessageIdData.getFirstChunkMessageId()CommandGetLastMessageIdResponse.getLastMessageId()CommandMessage.getMessageId()CommandSeek.getMessageId()CommandSend.getMessageId()CommandSendReceipt.getMessageId()CommandAck.getMessageIdAt(int idx) CommandRedeliverUnacknowledgedMessages.getMessageIdAt(int idx) CommandSubscribe.getStartMessageId()MessageIdData.setBatchIndex(int batchIndex) MessageIdData.setBatchSize(int batchSize) CommandGetLastMessageIdResponse.setConsumerMarkDeletePosition()MessageIdData.setEntryId(long entryId) MessageIdData.setFirstChunkMessageId()CommandGetLastMessageIdResponse.setLastMessageId()MessageIdData.setLedgerId(long ledgerId) CommandMessage.setMessageId()CommandSeek.setMessageId()CommandSend.setMessageId()CommandSendReceipt.setMessageId()MessageIdData.setPartition(int partition) CommandSubscribe.setStartMessageId()Methods in org.apache.pulsar.common.api.proto that return types with arguments of type MessageIdDataModifier and TypeMethodDescriptionCommandAck.getMessageIdsList()CommandRedeliverUnacknowledgedMessages.getMessageIdsList()Methods in org.apache.pulsar.common.api.proto with parameters of type MessageIdDataMethod parameters in org.apache.pulsar.common.api.proto with type arguments of type MessageIdDataModifier and TypeMethodDescriptionCommandAck.addAllMessageIds(Iterable<MessageIdData> messageIds) CommandRedeliverUnacknowledgedMessages.addAllMessageIds(Iterable<MessageIdData> messageIds) -
Uses of MessageIdData in org.apache.pulsar.common.protocol
Methods in org.apache.pulsar.common.protocol with parameters of type MessageIdDataModifier and TypeMethodDescriptionstatic io.netty.buffer.ByteBufCommands.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) static io.netty.buffer.ByteBufCommands.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) Method parameters in org.apache.pulsar.common.protocol with type arguments of type MessageIdDataModifier and TypeMethodDescriptionstatic io.netty.buffer.ByteBufCommands.newAck(long consumerId, List<MessageIdData> messageIds, CommandAck.AckType ackType, CommandAck.ValidationError validationError, Map<String, Long> properties, long txnIdLeastBits, long txnIdMostBits, long requestId) static io.netty.buffer.ByteBufCommands.newRedeliverUnacknowledgedMessages(long consumerId, List<MessageIdData> messageIds)