Modifier and Type | Method and Description |
---|---|
protected List<TopicPartition> |
BasePulsarSubscriber.toTopicPartitions(String topic,
int partitionId,
List<TopicRange> ranges,
RangeGenerator.KeySharedMode mode) |
protected List<TopicPartition> |
BasePulsarSubscriber.toTopicPartitions(TopicMetadata metadata,
List<TopicRange> ranges,
RangeGenerator.KeySharedMode mode) |
Modifier and Type | Method and Description |
---|---|
static TopicRange |
TopicRange.createFullRange()
Create a topic range which contains the full hash range.
|
Modifier and Type | Method and Description |
---|---|
List<TopicRange> |
TopicPartition.getRanges()
This method is internal used for serialization.
|
Constructor and Description |
---|
TopicPartition(String topic,
int partitionId,
List<TopicRange> ranges) |
TopicPartition(String topic,
int partitionId,
List<TopicRange> ranges,
RangeGenerator.KeySharedMode mode) |
Modifier and Type | Method and Description |
---|---|
List<TopicRange> |
SplitRangeGenerator.range(TopicMetadata metadata,
int parallelism) |
List<TopicRange> |
FixedRangeGenerator.range(TopicMetadata metadata,
int parallelism) |
List<TopicRange> |
FixedKeysRangeGenerator.range(TopicMetadata metadata,
int parallelism) |
List<TopicRange> |
RangeGenerator.range(TopicMetadata metadata,
int parallelism)
Generate range for the given topic.
|
List<TopicRange> |
FullRangeGenerator.range(TopicMetadata metadata,
int parallelism) |
Modifier and Type | Method and Description |
---|---|
static boolean |
TopicRangeUtils.isFullTopicRanges(List<TopicRange> ranges)
Check if the given topic ranges are full Pulsar range.
|
static void |
TopicRangeUtils.validateTopicRanges(List<TopicRange> ranges,
RangeGenerator.KeySharedMode sharedMode)
Make sure all the ranges should be valid in Pulsar Key Shared Policy.
|
Constructor and Description |
---|
FixedRangeGenerator(List<TopicRange> ranges) |
FixedRangeGenerator(List<TopicRange> ranges,
RangeGenerator.KeySharedMode sharedMode) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.