Package org.apache.kafka.streams
Class TopologyConfig
java.lang.Object
org.apache.kafka.common.config.AbstractConfig
org.apache.kafka.streams.TopologyConfig
Streams configs that apply at the topology level. The values in the 
StreamsConfig parameter of the
 KafkaStreams or KafkaStreamsNamedTopologyWrapper constructors will
 determine the defaults, which can then be overridden for specific topologies by passing them in when creating the
 topology builders via the StreamsBuilder(TopologyConfig) StreamsBuilder(TopologyConfig)} method.- 
Nested Class SummaryNested Classes
- 
Field SummaryFieldsModifier and TypeFieldDescriptionfinal StreamsConfigfinal longfinal booleanfinal intfinal longfinal Stringfinal longfinal Supplier<TimestampExtractor>final Stringfinal PropertiesFields inherited from class org.apache.kafka.common.config.AbstractConfigCONFIG_PROVIDERS_CONFIG
- 
Constructor SummaryConstructorsConstructorDescriptionTopologyConfig(String topologyName, StreamsConfig globalAppConfigs, Properties topologyOverrides) TopologyConfig(StreamsConfig globalAppConfigs) 
- 
Method SummaryModifier and TypeMethodDescriptionbooleanMethods inherited from class org.apache.kafka.common.config.AbstractConfigdocumentationOf, equals, get, getBoolean, getClass, getConfiguredInstance, getConfiguredInstance, getConfiguredInstances, getConfiguredInstances, getConfiguredInstances, getDouble, getInt, getList, getLong, getPassword, getShort, getString, hashCode, ignore, logUnused, nonInternalValues, originals, originals, originalsStrings, originalsWithPrefix, originalsWithPrefix, postProcessParsedConfig, typeOf, unused, values, valuesWithPrefixAllOrNothing, valuesWithPrefixOverride
- 
Field Details- 
topologyName
- 
eosEnabledpublic final boolean eosEnabled
- 
applicationConfigs
- 
topologyOverrides
- 
maxBufferedSizepublic final int maxBufferedSize
- 
cacheSizepublic final long cacheSize
- 
maxTaskIdleMspublic final long maxTaskIdleMs
- 
taskTimeoutMspublic final long taskTimeoutMs
- 
storeType
- 
timestampExtractorSupplier
- 
deserializationExceptionHandlerSupplier
 
- 
- 
Constructor Details- 
TopologyConfig
- 
TopologyConfigpublic TopologyConfig(String topologyName, StreamsConfig globalAppConfigs, Properties topologyOverrides) 
 
- 
- 
Method Details- 
parseStoreType
- 
isNamedTopologypublic boolean isNamedTopology()
- 
getTaskConfig
 
-