@PublicEvolving public class TopicPartition extends Object implements Serializable
SplitReader
, we create this topic
metas for a specified topic by subscription type and convert it into a partition split.Constructor and Description |
---|
TopicPartition(String topic,
int partitionId) |
TopicPartition(String topic,
int partitionId,
TopicRange range) |
Modifier and Type | Method and Description |
---|---|
boolean |
equals(Object o) |
String |
getFullTopicName()
Pulsar split the topic partition into a bunch of small topics, we would get the real topic
name by using this method.
|
int |
getPartitionId() |
org.apache.pulsar.client.api.Range |
getPulsarRange() |
TopicRange |
getRange() |
String |
getTopic() |
int |
hashCode() |
String |
toString() |
public TopicPartition(String topic, int partitionId)
public TopicPartition(String topic, int partitionId, TopicRange range)
public String getTopic()
public int getPartitionId()
public String getFullTopicName()
public TopicRange getRange()
public org.apache.pulsar.client.api.Range getPulsarRange()
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.