Class KafkaTridentSpoutConfig<K,V>
- java.lang.Object
- 
- org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig<K,V>
- 
- org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig<K,V>
 
 
- 
- All Implemented Interfaces:
- Serializable
 
 public class KafkaTridentSpoutConfig<K,V> extends CommonKafkaSpoutConfig<K,V> Defines the required Kafka-related configuration for the Trident spouts.- See Also:
- Serialized Form
 
- 
- 
Nested Class SummaryNested Classes Modifier and Type Class Description static classKafkaTridentSpoutConfig.Builder<K,V>
 - 
Field Summary- 
Fields inherited from class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfigDEFAULT_FIRST_POLL_OFFSET_STRATEGY, DEFAULT_PARTITION_REFRESH_PERIOD_MS, DEFAULT_POLL_TIMEOUT_MS, DEFAULT_START_TS, LOG
 
- 
 - 
Constructor SummaryConstructors Constructor Description KafkaTridentSpoutConfig(KafkaTridentSpoutConfig.Builder<K,V> builder)
 - 
Method SummaryAll Methods Static Methods Concrete Methods Modifier and Type Method Description static KafkaTridentSpoutConfig.Builder<String,String>builder(String bootstrapServers, String... topics)Factory method that creates a Builder with String key/value deserializers.static KafkaTridentSpoutConfig.Builder<String,String>builder(String bootstrapServers, Pattern topics)Factory method that creates a Builder with String key/value deserializers.static KafkaTridentSpoutConfig.Builder<String,String>builder(String bootstrapServers, Set<String> topics)Factory method that creates a Builder with String key/value deserializers.- 
Methods inherited from class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfiggetFirstPollOffsetStrategy, getKafkaProps, getPartitionRefreshPeriodMs, getPollTimeoutMs, getStartTimeStamp, getTopicFilter, getTopicPartitioner, getTranslator, toString
 
- 
 
- 
- 
- 
Constructor Detail- 
KafkaTridentSpoutConfigpublic KafkaTridentSpoutConfig(KafkaTridentSpoutConfig.Builder<K,V> builder) 
 
- 
 - 
Method Detail- 
builderpublic static KafkaTridentSpoutConfig.Builder<String,String> builder(String bootstrapServers, String... topics) Factory method that creates a Builder with String key/value deserializers.- Parameters:
- bootstrapServers- The bootstrap servers for the consumer
- topics- The topics to subscribe to
- Returns:
- The new builder
 
 - 
builderpublic static KafkaTridentSpoutConfig.Builder<String,String> builder(String bootstrapServers, Set<String> topics) Factory method that creates a Builder with String key/value deserializers.- Parameters:
- bootstrapServers- The bootstrap servers for the consumer
- topics- The topics to subscribe to
- Returns:
- The new builder
 
 - 
builderpublic static KafkaTridentSpoutConfig.Builder<String,String> builder(String bootstrapServers, Pattern topics) Factory method that creates a Builder with String key/value deserializers.- Parameters:
- bootstrapServers- The bootstrap servers for the consumer
- topics- The topic pattern to subscribe to
- Returns:
- The new builder
 
 
- 
 
-