public class TopologyConfig
extends org.apache.kafka.common.config.AbstractConfig
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 org.apache.kafka.streams.StreamsBuilder()
method.Modifier and Type | Class and Description |
---|---|
static class |
TopologyConfig.TaskConfig |
Modifier and Type | Field and Description |
---|---|
StreamsConfig |
applicationConfigs |
long |
cacheSize |
Supplier<DeserializationExceptionHandler> |
deserializationExceptionHandlerSupplier |
boolean |
eosEnabled |
int |
maxBufferedSize |
long |
maxTaskIdleMs |
String |
storeType |
long |
taskTimeoutMs |
Supplier<TimestampExtractor> |
timestampExtractorSupplier |
String |
topologyName |
Properties |
topologyOverrides |
Constructor and Description |
---|
TopologyConfig(StreamsConfig globalAppConfigs) |
TopologyConfig(String topologyName,
StreamsConfig globalAppConfigs,
Properties topologyOverrides) |
Modifier and Type | Method and Description |
---|---|
TopologyConfig.TaskConfig |
getTaskConfig() |
boolean |
isNamedTopology() |
Materialized.StoreType |
parseStoreType() |
documentationOf, 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
public final String topologyName
public final boolean eosEnabled
public final StreamsConfig applicationConfigs
public final Properties topologyOverrides
public final int maxBufferedSize
public final long cacheSize
public final long maxTaskIdleMs
public final long taskTimeoutMs
public final String storeType
public final Supplier<TimestampExtractor> timestampExtractorSupplier
public final Supplier<DeserializationExceptionHandler> deserializationExceptionHandlerSupplier
public TopologyConfig(StreamsConfig globalAppConfigs)
public TopologyConfig(String topologyName, StreamsConfig globalAppConfigs, Properties topologyOverrides)
public Materialized.StoreType parseStoreType()
public boolean isNamedTopology()
public TopologyConfig.TaskConfig getTaskConfig()