Interface TopicFilter

All Superinterfaces:
Serializable
All Known Implementing Classes:
NamedTopicFilter, PatternTopicFilter

public interface TopicFilter extends Serializable
  • Method Summary

    Modifier and Type
    Method
    Description
    Set<org.apache.kafka.common.TopicPartition>
    getAllSubscribedPartitions(org.apache.kafka.clients.consumer.Consumer<?,?> consumer)
    Get the Kafka TopicPartitions subscribed to by this set of spouts.
    Get the topics string.
  • Method Details

    • getAllSubscribedPartitions

      Set<org.apache.kafka.common.TopicPartition> getAllSubscribedPartitions(org.apache.kafka.clients.consumer.Consumer<?,?> consumer)
      Get the Kafka TopicPartitions subscribed to by this set of spouts.
      Parameters:
      consumer - The Kafka consumer to use to read the list of existing partitions
      Returns:
      The Kafka partitions this set of spouts should subscribe to
    • getTopicsString

      String getTopicsString()
      Get the topics string.
      Returns:
      A human-readable string representing the topics that pass the filter.