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 constructor or the KafkaStreamsNamedTopologyWrapper constructor (deprecated)
 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) constructor for DSL applications,
 or the Topology(TopologyConfig) for PAPI applications.
 
 Note that some configs, such as the processor.wrapper.class config, can only take effect while the
 topology is being built, which means they have to be passed in as a TopologyConfig to the
 Topology(TopologyConfig) constructor (PAPI) or the
 StreamsBuilder(TopologyConfig) constructor (DSL).
 If they are only set in the configs passed in to the KafkaStreams constructor, it will be too late for them
 to be applied and the config will be ignored.
- 
Nested Class SummaryNested ClassesModifier and TypeClassDescriptionstatic classstatic class
- 
Field SummaryFieldsModifier and TypeFieldDescriptionfinal StreamsConfigfinal longfinal Class<?> final booleanfinal intfinal longfinal Stringfinal longfinal Supplier<TimestampExtractor> final Stringfinal PropertiesFields inherited from class org.apache.kafka.common.config.AbstractConfigAUTOMATIC_CONFIG_PROVIDERS_PROPERTY, CONFIG_PROVIDERS_CONFIG
- 
Constructor SummaryConstructorsConstructorDescriptionTopologyConfig(String topologyName, StreamsConfig globalAppConfigs, Properties topologyOverrides) TopologyConfig(StreamsConfig configs) 
- 
Method SummaryModifier and TypeMethodDescriptionbooleanDeprecated.Methods inherited from class org.apache.kafka.common.config.AbstractConfigdocumentationOf, equals, getBoolean, getClass, getConfiguredInstance, getConfiguredInstance, getConfiguredInstances, getConfiguredInstances, getConfiguredInstances, getDouble, getInt, getList, getLong, getPassword, getShort, getString, hashCode, ignore, logUnused, nonInternalValues, originals, originals, originalsStrings, originalsWithPrefix, originalsWithPrefix, 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
- 
dslStoreSuppliers
- 
timestampExtractorSupplier
- 
deserializationExceptionHandlerSupplier
- 
processingExceptionHandlerSupplier
 
- 
- 
Constructor Details- 
TopologyConfig
- 
TopologyConfigpublic TopologyConfig(String topologyName, StreamsConfig globalAppConfigs, Properties topologyOverrides) 
 
- 
- 
Method Details- 
parseStoreTypeDeprecated.
- 
resolveDslStoreSuppliers- Returns:
- the DslStoreSuppliers if the value was explicitly configured (either by
         StreamsConfig.DEFAULT_DSL_STOREorStreamsConfig.DSL_STORE_SUPPLIERS_CLASS_CONFIG)
 
- 
isNamedTopologypublic boolean isNamedTopology()
- 
getTaskConfig
 
-