Class NamedTopicFilter

    • Constructor Detail

      • NamedTopicFilter

        public NamedTopicFilter​(Set<String> topics)
        Create filter based on a set of topic names.
        Parameters:
        topics - The topic names the filter will pass.
      • NamedTopicFilter

        public NamedTopicFilter​(String... topics)
        Convenience constructor.
        Parameters:
        topics - The topic names the filter will pass.
    • Method Detail

      • getAllSubscribedPartitions

        public Set<org.apache.kafka.common.TopicPartition> getAllSubscribedPartitions​(org.apache.kafka.clients.consumer.Consumer<?,​?> consumer)
        Description copied from interface: TopicFilter
        Get the Kafka TopicPartitions subscribed to by this set of spouts.
        Specified by:
        getAllSubscribedPartitions in interface TopicFilter
        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

        public String getTopicsString()
        Description copied from interface: TopicFilter
        Get the topics string.
        Specified by:
        getTopicsString in interface TopicFilter
        Returns:
        A human-readable string representing the topics that pass the filter.