TopologyDefinition
KSML definition
Properties
functions
(object): (optional) Functions that can be referenced in producers and pipelines.^[a-zA-Z0-9_]+$
- Any of
- object: Refer to #/definitions/AggregatorDefinition.
- object: Refer to #/definitions/ForEachActionDefinition.
- object: Refer to #/definitions/ForeignKeyExtractorDefinition.
- object: Refer to #/definitions/GeneratorDefinition.
- object: Refer to #/definitions/GenericFunctionDefinitionWithImplicitType.
- object: Refer to #/definitions/InitializerDefinition.
- object: Refer to #/definitions/KeyTransformerDefinition.
- object: Refer to #/definitions/KeyValueMapperDefinition.
- object: Refer to #/definitions/KeyValuePrinterDefinition.
- object: Refer to #/definitions/KeyValueToKeyValueListTransformerDefinition.
- object: Refer to #/definitions/KeyValueToValueListTransformerDefinition.
- object: Refer to #/definitions/KeyValueTransformerDefinition.
- object: Refer to #/definitions/MergerDefinition.
- object: Refer to #/definitions/MetadataTransformerDefinition.
- object: Refer to #/definitions/PredicateDefinition.
- object: Refer to #/definitions/ReducerDefinition.
- object: Refer to #/definitions/StreamPartitionerDefinition.
- object: Refer to #/definitions/TimestampExtractorDefinition.
- object: Refer to #/definitions/TopicNameExtractorDefinition.
- object: Refer to #/definitions/ValueJoinerDefinition.
- object: Refer to #/definitions/ValueTransformerDefinition.
- Any of
globalTables
(object): (optional) GlobalTables that can be referenced in producers and pipelines.^[a-zA-Z0-9_]+$
(object): Refer to #/definitions/GlobalTableDefinitionSource.
pipelines
(object): (optional) Collection of named pipelines.^[a-zA-Z0-9_]+$
(object): Refer to #/definitions/PipelineDefinition.
producers
(object): (optional) Collection of named producers.^[a-zA-Z0-9_]+$
(object): Refer to #/definitions/ProducerDefinition.
stores
(object): (optional) State stores that can be referenced in producers and pipelines.^[a-zA-Z0-9_]+$
- Any of
- object: Refer to #/definitions/KeyValueStateStoreDefinition.
- object: Refer to #/definitions/SessionStateStoreDefinition.
- object: Refer to #/definitions/WindowStateStoreDefinition.
- Any of
streams
(object): (optional) Streams that can be referenced in producers and pipelines.^[a-zA-Z0-9_]+$
(object): Refer to #/definitions/StreamDefinitionSource.
tables
(object): (optional) Tables that can be referenced in producers and pipelines.^[a-zA-Z0-9_]+$
(object): Refer to #/definitions/TableDefinitionSource.Definitions
AggregateOperation
(object): An aggregate operation. Cannot contain additional properties.adder
: (optional) (GroupedTable) A function that adds a record to the aggregation result.- Any of
- string
- object: Refer to #/definitions/AggregatorDefinitionWithImplicitType.
- Any of
aggregator
: (optional) (GroupedStream, SessionWindowedStream, TimeWindowedStream) The aggregator function, which combines a value with the previous aggregation result and outputs a new aggregation result.- Any of
- string
- object: Refer to #/definitions/AggregatorDefinitionWithImplicitType.
- Any of
initializer
: The initializer function, which generates an initial value for every set of aggregated records.- Any of
- string
- object: Refer to #/definitions/InitializerDefinitionWithImplicitType.
- Any of
merger
: (optional) (SessionWindowedStream, SessionWindowedCogroupedStream) A function that combines two aggregation results.- Any of
- string
- object: Refer to #/definitions/MergerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the result aggregation.- Any of
- string
- object: Refer to #/definitions/WindowStateStoreDefinitionWithImplicitType.
- Any of
subtractor
: (optional) (GroupedTable) A function that removes a record from the aggregation result.- Any of
- string
- object: Refer to #/definitions/AggregatorDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["aggregate"]
.
AggregatorDefinition
(object): Defines a aggregator function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the aggregator.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the aggregator. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the aggregator. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the aggregator. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the aggregator.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the aggregator. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["aggregator"]
.
AggregatorDefinitionWithImplicitType
(object): Defines a aggregator function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the aggregator.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the aggregator. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the aggregator. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the aggregator. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the aggregator.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the aggregator. Only required for function types, which are not pre-defined.
BranchDefinitionWithPipeline
(object): Defines a branch with sub-pipeline in a BranchOperation. Cannot contain additional properties.as
(string): (optional) The name to register the pipeline result under, which can be used as source by follow-up pipelines.branch
(array): (optional) Defines a single branch, consisting of a condition and a pipeline to execute for messages that fulfil the predicate.- Items (object): Refer to #/definitions/StringOrInlinePredicateDefinitionWithImplicitType.
forEach
: (optional) A function that gets called for every message in the stream.- Any of
- string
- object: Refer to #/definitions/ForEachActionDefinitionWithImplicitType.
- Any of
if
: (optional) Defines the condition under which messages get sent down this branch.- Any of
- string
- object: Refer to #/definitions/PredicateDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.print
(object): (optional) The specification of where to print messages to. Refer to #/definitions/PrintOperation.to
: (optional) Ends the pipeline by sending all messages to a stream, table or globalTable, or to an inline defined output topic and optional partitioner.- Any of
- string
- object: Refer to #/definitions/ToTopicDefinition.
- Any of
toTopicNameExtractor
: (optional) Ends the pipeline by sending all messages to a topic provided by a pre-defined topic name extractor function, or to a topic provided by an inline defined topic name extractor and optional partitioner.- Any of
- string
- object: Refer to #/definitions/ToTopicNameExtractorDefinition.
- Any of
via
(array): (optional) A series of operations performed on the input stream.- Items
- Any of
- object: Refer to #/definitions/AggregateOperation.
- object: Refer to #/definitions/CogroupOperation.
- object: Refer to #/definitions/ConvertKeyOperation.
- object: Refer to #/definitions/ConvertKeyValueOperation.
- object: Refer to #/definitions/ConvertValueOperation.
- object: Refer to #/definitions/CountOperation.
- object: Refer to #/definitions/FilterNotOperation.
- object: Refer to #/definitions/FilterOperation.
- object: Refer to #/definitions/GroupByKeyOperation.
- object: Refer to #/definitions/GroupByOperation.
- object: Refer to #/definitions/JoinOperationWithGlobalTable.
- object: Refer to #/definitions/JoinOperationWithStream.
- object: Refer to #/definitions/JoinOperationWithTable.
- object: Refer to #/definitions/LeftJoinOperationWithGlobalTable.
- object: Refer to #/definitions/LeftJoinOperationWithStream.
- object: Refer to #/definitions/LeftJoinOperationWithTable.
- object: Refer to #/definitions/MergeOperation.
- object: Refer to #/definitions/OuterJoinOperationWithStream.
- object: Refer to #/definitions/OuterJoinOperationWithTable.
- object: Refer to #/definitions/PeekOperation.
- object: Refer to #/definitions/ReduceOperationWithAdderAndSubtractor.
- object: Refer to #/definitions/ReduceOperationWithReducer.
- object: Refer to #/definitions/RepartitionOperation.
- object: Refer to #/definitions/SuppressOperationUntilTimeLimit.
- object: Refer to #/definitions/SuppressOperationUntilWindowCloses.
- object: Refer to #/definitions/ToStreamOperation.
- object: Refer to #/definitions/ToTableOperation.
- object: Refer to #/definitions/TransformKeyOperation.
- object: Refer to #/definitions/TransformKeyValueOperation.
- object: Refer to #/definitions/TransformKeyValueToKeyValueListOperation.
- object: Refer to #/definitions/TransformKeyValueToValueListOperation.
- object: Refer to #/definitions/TransformMetadataOperation.
- object: Refer to #/definitions/TransformValueOperation.
- object: Refer to #/definitions/WindowBySessionOperation.
- object: Refer to #/definitions/WindowByTimeOperationWithHoppingWindow.
- object: Refer to #/definitions/WindowByTimeOperationWithSlidingWindow.
- object: Refer to #/definitions/WindowByTimeOperationWithTumblingWindow.
- Any of
- Items
CogroupOperation
(object): A cogroup operation. Cannot contain additional properties.aggregator
: (GroupedStream, SessionWindowedStream, TimeWindowedStream) The aggregator function, which combines a value with the previous aggregation result and outputs a new aggregation result.- Any of
- string
- object: Refer to #/definitions/AggregatorDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the co-grouped stream.- Any of
- string
- object: Refer to #/definitions/WindowStateStoreDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["cogroup"]
.
ConvertKeyOperation
(object): An operation to convert the stream key type to another type. Conversion is only syntactic, eg. from Avro to XML. Cannot contain additional properties.into
(string, required): The type to convert the stream key into.name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["convertKey"]
.
ConvertKeyValueOperation
(object): An operation to convert the stream key and value types to other types. Conversion is only syntactic, eg. from Avro to XML. Cannot contain additional properties.into
(string, required): The tuple type to convert the stream key/value into.name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["convertKeyValue"]
.
ConvertValueOperation
(object): An operation to convert the stream value type to another type. Conversion is only syntactic, eg. from Avro to XML. Cannot contain additional properties.into
(string, required): The type to convert the stream value into.name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["convertValue"]
.
CountOperation
(object): Count the number of times a key is seen in a given window. Cannot contain additional properties.name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the count operation’s result.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinition.
- object: Refer to #/definitions/SessionStateStoreDefinition.
- object: Refer to #/definitions/WindowStateStoreDefinition.
- Any of
type
: The type of the operation. Must be one of:["count"]
.
FilterNotOperation
(object): Filter records based on the inverse result of a predicate function. Cannot contain additional properties.if
: A function that returns “false” when records are accepted, “true” otherwise.- Any of
- string
- object: Refer to #/definitions/PredicateDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the filtered table (only applies to tables, ignored for streams).- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["filterNot"]
.
FilterOperation
(object): Filter records based on a predicate function. Cannot contain additional properties.if
: A function that returns “true” when records are accepted, “false” otherwise.- Any of
- string
- object: Refer to #/definitions/PredicateDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the filtered table (only applies to tables, ignored for streams).- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["filter"]
.
ForEachActionDefinition
(object): Defines a foreach action function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the foreach action.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the foreach action. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the foreach action. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the foreach action. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the foreach action.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the foreach action. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the foreach action uses. Only required if the function wants to use a state store.- Items (string)
type
: The type of the function. Must be one of:["forEach"]
.
ForEachActionDefinitionWithImplicitType
(object): Defines a foreach action function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the foreach action.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the foreach action. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the foreach action. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the foreach action. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the foreach action.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the foreach action. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the foreach action uses. Only required if the function wants to use a state store.- Items (string)
ForeignKeyExtractorDefinition
(object): Defines a foreign key extractor function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the foreign key extractor.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the foreign key extractor. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the foreign key extractor. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the foreign key extractor. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the foreign key extractor.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the foreign key extractor. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["foreignKeyExtractor"]
.
ForeignKeyExtractorDefinitionWithImplicitType
(object): Defines a foreign key extractor function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the foreign key extractor.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the foreign key extractor. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the foreign key extractor. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the foreign key extractor. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the foreign key extractor.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the foreign key extractor. Only required for function types, which are not pre-defined.
GeneratorDefinition
(object): Defines a message generator function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the message generator.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the message generator. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the message generator. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the message generator. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the message generator.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the message generator. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["generator"]
.
GeneratorDefinitionWithImplicitType
(object): Defines a message generator function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the message generator.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the message generator. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the message generator. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the message generator. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the message generator.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the message generator. Only required for function types, which are not pre-defined.
GenericFunctionDefinitionWithImplicitType
(object): Defines a generic function function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the generic function.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the generic function. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the generic function. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the generic function. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the generic function.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the generic function. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["generic"]
.
GlobalTableDefinition
(object): Contains a definition of a GlobalTable, which can be referenced by producers and pipelines. Cannot contain additional properties.keyType
(string): (optional) The key type of the global table.store
: (optional) KeyValue state store definition.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
topic
(string, required): The name of the Kafka topic for this global table.valueType
(string): (optional) The value type of the global table.
GlobalTableDefinitionSource
(object): Contains a definition of a GlobalTable, which can be referenced by producers and pipelines. Cannot contain additional properties.keyType
(string, required): The key type of the global table.offsetResetPolicy
(string): (optional) Policy that determines what to do when there is no initial offset in Kafka, or if the current offset does not exist any more on the server (e.g. because that data has been deleted).store
: (optional) KeyValue state store definition.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
timestampExtractor
: (optional) A function extracts the event time from a consumed record.- Any of
- string
- object: Refer to #/definitions/TimestampExtractorDefinitionWithImplicitType.
- Any of
topic
(string, required): The name of the Kafka topic for this global table.valueType
(string, required): The value type of the global table.
GroupByKeyOperation
(object): Operation to group all messages with the same key together. Cannot contain additional properties.name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the grouped stream.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["groupByKey"]
.
GroupByOperation
(object): Operation to group all messages with together based on a keying function. Cannot contain additional properties.mapper
: Function to map records to a key they can be grouped on.- Any of
- string
- object: Refer to #/definitions/KeyValueMapperDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the grouped stream or table.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["groupBy"]
.
InitializerDefinition
(object): Defines a initializer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the initializer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the initializer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the initializer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the initializer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the initializer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the initializer. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["initializer"]
.
InitializerDefinitionWithImplicitType
(object): Defines a initializer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the initializer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the initializer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the initializer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the initializer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the initializer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the initializer. Only required for function types, which are not pre-defined.
JoinOperationWithGlobalTable
(object): Operation to join with a table. Cannot contain additional properties.globalTable
: A reference to the globalTable, or an inline definition of the globalTable to join with.- Any of
- string
- object: Refer to #/definitions/GlobalTableDefinition.
- Any of
mapper
: A function that maps the key value from the stream to the primary key type of the globalTable.- Any of
- string
- object: Refer to #/definitions/KeyValueMapperDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["join"]
.valueJoiner
: A function that joins two values.- Any of
- string
- object: Refer to #/definitions/ValueJoinerDefinitionWithImplicitType.
- Any of
JoinOperationWithStream
(object): Operation to join with a stream. Cannot contain additional properties.grace
: (optional) The window grace period (the time to admit out-of-order events after the end of the window).- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the joined streams.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinition.
- object: Refer to #/definitions/SessionStateStoreDefinition.
- object: Refer to #/definitions/WindowStateStoreDefinition.
- Any of
stream
: A reference to the Stream, or an inline definition of the stream to join with.- Any of
- string
- object: Refer to #/definitions/StreamDefinition.
- Any of
timeDifference
: The maximum time difference for a join over two streams on the same key.- Any of
- number
- string
- Any of
type
: The type of the operation. Must be one of:["join"]
.valueJoiner
: A function that joins two values.- Any of
- string
- object: Refer to #/definitions/ValueJoinerDefinitionWithImplicitType.
- Any of
JoinOperationWithTable
(object): Operation to join with a table. Cannot contain additional properties.foreignKeyExtractor
: (optional) A function that can translate the join table value to a primary key.- Any of
- string
- object: Refer to #/definitions/ForeignKeyExtractorDefinitionWithImplicitType.
- Any of
grace
: (optional) The window grace period (the time to admit out-of-order events after the end of the window).- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.otherPartitioner
: (optional) A function that partitions the records on the join table.- Any of
- string
- object: Refer to #/definitions/StreamPartitionerDefinitionWithImplicitType.
- Any of
partitioner
: (optional) A function that partitions the records on the primary table.- Any of
- string
- object: Refer to #/definitions/StreamPartitionerDefinitionWithImplicitType.
- Any of
store
: (optional) Materialized view of the joined streams.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinition.
- object: Refer to #/definitions/SessionStateStoreDefinition.
- object: Refer to #/definitions/WindowStateStoreDefinition.
- Any of
table
: A reference to the table, or an inline definition of the table to join with.- Any of
- string
- object: Refer to #/definitions/TableDefinition.
- Any of
type
: The type of the operation. Must be one of:["join"]
.valueJoiner
: A function that joins two values.- Any of
- string
- object: Refer to #/definitions/ValueJoinerDefinitionWithImplicitType.
- Any of
KeyTransformerDefinition
(object): Defines a key transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the key transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the key transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the key transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the key transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the key transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the key transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the key transformer uses. Only required if the function wants to use a state store.- Items (string)
type
: The type of the function. Must be one of:["keyTransformer"]
.
KeyTransformerDefinitionWithImplicitType
(object): Defines a key transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the key transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the key transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the key transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the key transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the key transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the key transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the key transformer uses. Only required if the function wants to use a state store.- Items (string)
KeyValueMapperDefinition
(object): Defines a keyvalue mapper function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue mapper.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue mapper. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue mapper. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue mapper. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue mapper.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue mapper. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["keyValueMapper"]
.
KeyValueMapperDefinitionWithImplicitType
(object): Defines a keyvalue mapper function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue mapper.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue mapper. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue mapper. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue mapper. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue mapper.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue mapper. Only required for function types, which are not pre-defined.
KeyValuePrinterDefinition
(object): Defines a keyvalue printer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue printer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue printer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue printer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue printer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue printer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue printer. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["keyValuePrinter"]
.
KeyValuePrinterDefinitionWithImplicitType
(object): Defines a keyvalue printer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue printer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue printer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue printer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue printer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue printer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue printer. Only required for function types, which are not pre-defined.
KeyValueStateStoreDefinition
(object): Definition of a keyValue state store. Cannot contain additional properties.caching
(boolean): (optional) “true” if changed to the keyValue store need to be buffered and periodically released, “false” to emit all changes directly.historyRetention
: (optional) (Versioned only) The duration for which old record versions are available for query (cannot be negative).- Any of
- number
- string
- Any of
keyType
(string): (optional) The key type of the keyValue store.logging
(boolean): (optional) “true” if a changelog topic should be set up on Kafka for this keyValue store, “false” otherwise.name
(string): (optional) The name of the keyValue store. If this field is not defined, then the name is derived from the context.persistent
(boolean): (optional) “true” if this keyValue store needs to be stored on disk, “false” otherwise.segmentInterval
: (optional) Size of segments for storing old record versions (must be positive). Old record versions for the same key in a single segment are stored (updated and accessed) together. The only impact of this parameter is performance. If segments are large and a workload results in many record versions for the same key being collected in a single segment, performance may degrade as a result. On the other hand, historical reads (which access older segments) and out-of-order writes may slow down if there are too many segments.- Any of
- number
- string
- Any of
timestamped
(boolean): (optional) “true” if elements in the store are timestamped, “false” otherwise.type
: The type of the state store. Must be one of:["keyValue"]
.valueType
(string): (optional) The value type of the keyValue store.versioned
(boolean): (optional) “true” if elements in the store are versioned, “false” otherwise.
KeyValueStateStoreDefinitionWithImplicitType
(object): Definition of a keyValue state store. Cannot contain additional properties.caching
(boolean): (optional) “true” if changed to the keyValue store need to be buffered and periodically released, “false” to emit all changes directly.historyRetention
: (optional) (Versioned only) The duration for which old record versions are available for query (cannot be negative).- Any of
- number
- string
- Any of
keyType
(string): (optional) The key type of the keyValue store.logging
(boolean): (optional) “true” if a changelog topic should be set up on Kafka for this keyValue store, “false” otherwise.name
(string): (optional) The name of the keyValue store. If this field is not defined, then the name is derived from the context.persistent
(boolean): (optional) “true” if this keyValue store needs to be stored on disk, “false” otherwise.segmentInterval
: (optional) Size of segments for storing old record versions (must be positive). Old record versions for the same key in a single segment are stored (updated and accessed) together. The only impact of this parameter is performance. If segments are large and a workload results in many record versions for the same key being collected in a single segment, performance may degrade as a result. On the other hand, historical reads (which access older segments) and out-of-order writes may slow down if there are too many segments.- Any of
- number
- string
- Any of
timestamped
(boolean): (optional) “true” if elements in the store are timestamped, “false” otherwise.type
: The type of the state store. Must be one of:["keyValue"]
.valueType
(string): (optional) The value type of the keyValue store.versioned
(boolean): (optional) “true” if elements in the store are versioned, “false” otherwise.
KeyValueToKeyValueListTransformerDefinition
(object): Defines a keyvalue-to-keyvaluelist transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue-to-keyvaluelist transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue-to-keyvaluelist transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue-to-keyvaluelist transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue-to-keyvaluelist transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue-to-keyvaluelist transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue-to-keyvaluelist transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the keyvalue-to-keyvaluelist transformer uses. Only required if the function wants to use a state store.- Items (string)
type
: The type of the function. Must be one of:["keyValueToKeyValueListTransformer"]
.
KeyValueToKeyValueListTransformerDefinitionWithImplicitType
(object): Defines a keyvalue-to-keyvaluelist transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue-to-keyvaluelist transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue-to-keyvaluelist transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue-to-keyvaluelist transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue-to-keyvaluelist transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue-to-keyvaluelist transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue-to-keyvaluelist transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the keyvalue-to-keyvaluelist transformer uses. Only required if the function wants to use a state store.- Items (string)
KeyValueToValueListTransformerDefinition
(object): Defines a keyvalue-to-valuelist transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue-to-valuelist transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue-to-valuelist transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue-to-valuelist transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue-to-valuelist transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue-to-valuelist transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue-to-valuelist transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the keyvalue-to-valuelist transformer uses. Only required if the function wants to use a state store.- Items (string)
type
: The type of the function. Must be one of:["keyValueToValueListTransformer"]
.
KeyValueToValueListTransformerDefinitionWithImplicitType
(object): Defines a keyvalue-to-valuelist transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue-to-valuelist transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue-to-valuelist transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue-to-valuelist transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue-to-valuelist transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue-to-valuelist transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue-to-valuelist transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the keyvalue-to-valuelist transformer uses. Only required if the function wants to use a state store.- Items (string)
KeyValueTransformerDefinition
(object): Defines a keyvalue transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the keyvalue transformer uses. Only required if the function wants to use a state store.- Items (string)
type
: The type of the function. Must be one of:["keyValueTransformer"]
.
KeyValueTransformerDefinitionWithImplicitType
(object): Defines a keyvalue transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the keyvalue transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the keyvalue transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the keyvalue transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the keyvalue transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the keyvalue transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the keyvalue transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the keyvalue transformer uses. Only required if the function wants to use a state store.- Items (string)
LeftJoinOperationWithGlobalTable
(object): Operation to leftJoin with a globalTable. Cannot contain additional properties.globalTable
: A reference to the globalTable, or an inline definition of the globalTable to join with.- Any of
- string
- object: Refer to #/definitions/GlobalTableDefinition.
- Any of
mapper
: A function that maps the key value from the stream with the primary key of the globalTable.- Any of
- string
- object: Refer to #/definitions/KeyValueMapperDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["leftJoin"]
.valueJoiner
: A function that joins two values.- Any of
- string
- object: Refer to #/definitions/ValueJoinerDefinitionWithImplicitType.
- Any of
LeftJoinOperationWithStream
(object): Operation to leftJoin with a stream. Cannot contain additional properties.grace
: (optional) The window grace period (the time to admit out-of-order events after the end of the window).- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the joined streams.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinition.
- object: Refer to #/definitions/SessionStateStoreDefinition.
- object: Refer to #/definitions/WindowStateStoreDefinition.
- Any of
stream
: A reference to the stream, or an inline definition of the stream to leftJoin with.- Any of
- string
- object: Refer to #/definitions/StreamDefinition.
- Any of
timeDifference
: The maximum time difference for a leftJoin over two streams on the same key.- Any of
- number
- string
- Any of
type
: The type of the operation. Must be one of:["leftJoin"]
.valueJoiner
: A function that joins two values.- Any of
- string
- object: Refer to #/definitions/ValueJoinerDefinitionWithImplicitType.
- Any of
LeftJoinOperationWithTable
(object): Operation to leftJoin with a table. Cannot contain additional properties.foreignKeyExtractor
: (optional) A function that can translate the join table value to a primary key.- Any of
- string
- object: Refer to #/definitions/ForeignKeyExtractorDefinitionWithImplicitType.
- Any of
grace
: (optional) The window grace period (the time to admit out-of-order events after the end of the window).- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.otherPartitioner
: (optional) A function that partitions the records on the join table.- Any of
- string
- object: Refer to #/definitions/StreamPartitionerDefinitionWithImplicitType.
- Any of
partitioner
: (optional) A function that partitions the records on the primary table.- Any of
- string
- object: Refer to #/definitions/StreamPartitionerDefinitionWithImplicitType.
- Any of
store
: (optional) Materialized view of the joined streams.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinition.
- object: Refer to #/definitions/SessionStateStoreDefinition.
- object: Refer to #/definitions/WindowStateStoreDefinition.
- Any of
table
: A reference to the Table, or an inline definition of the Table to join with.- Any of
- string
- object: Refer to #/definitions/TableDefinition.
- Any of
type
: The type of the operation. Must be one of:["leftJoin"]
.valueJoiner
: A function that joins two values.- Any of
- string
- object: Refer to #/definitions/ValueJoinerDefinitionWithImplicitType.
- Any of
MergeOperation
(object): A merge operation to join two Streams. Cannot contain additional properties.name
(string): (optional) The name of the operation processor.stream
: The stream to merge with.- Any of
- string
- object: Refer to #/definitions/StreamDefinitionSource.
- Any of
type
: The type of the operation. Must be one of:["merge"]
.
MergerDefinition
(object): Defines a merger function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the merger.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the merger. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the merger. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the merger. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the merger.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the merger. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["merger"]
.
MergerDefinitionWithImplicitType
(object): Defines a merger function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the merger.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the merger. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the merger. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the merger. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the merger.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the merger. Only required for function types, which are not pre-defined.
MetadataTransformerDefinition
(object): Defines a metadata transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the metadata transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the metadata transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the metadata transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the metadata transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the metadata transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the metadata transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the metadata transformer uses. Only required if the function wants to use a state store.- Items (string)
type
: The type of the function. Must be one of:["metadataTransformer"]
.
MetadataTransformerDefinitionWithImplicitType
(object): Defines a metadata transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the metadata transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the metadata transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the metadata transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the metadata transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the metadata transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the metadata transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the metadata transformer uses. Only required if the function wants to use a state store.- Items (string)
OuterJoinOperationWithStream
(object): Operation to outerJoin with a stream. Cannot contain additional properties.grace
: (optional) The window grace period (the time to admit out-of-order events after the end of the window).- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the outerJoined streams.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinition.
- object: Refer to #/definitions/SessionStateStoreDefinition.
- object: Refer to #/definitions/WindowStateStoreDefinition.
- Any of
stream
: A reference to the stream, or an inline definition of the stream to outerJoin with.- Any of
- string
- object: Refer to #/definitions/StreamDefinition.
- Any of
timeDifference
: The maximum time difference for an outerJoin over two streams on the same key.- Any of
- number
- string
- Any of
type
: The type of the operation. Must be one of:["outerJoin"]
.valueJoiner
: A function that joins two values.- Any of
- string
- object: Refer to #/definitions/ValueJoinerDefinitionWithImplicitType.
- Any of
OuterJoinOperationWithTable
(object): Operation to outerJoin with a table. Cannot contain additional properties.name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the outerJoined streams.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinition.
- object: Refer to #/definitions/SessionStateStoreDefinition.
- object: Refer to #/definitions/WindowStateStoreDefinition.
- Any of
table
: A reference to the table, or an inline definition of the table to outerJoin with.- Any of
- string
- object: Refer to #/definitions/TableDefinition.
- Any of
type
: The type of the operation. Must be one of:["outerJoin"]
.valueJoiner
: A function that joins two values.- Any of
- string
- object: Refer to #/definitions/ValueJoinerDefinitionWithImplicitType.
- Any of
ParameterDefinition
(object): Defines a parameter for a user function. Cannot contain additional properties.defaultValue
(string): (optional) The default value for the parameter.name
(string, required): The name of the parameter.type
(string, required): The type of the parameter.
PeekOperation
(object): Operation to peek into a stream, without modifying the stream contents. Cannot contain additional properties.forEach
: A function that gets called for every message in the stream.- Any of
- string
- object: Refer to #/definitions/ForEachActionDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["peek"]
.
PipelineDefinition
(object): Defines a pipeline through a source, a series of operations to perform on it and a sink operation to close the stream with. Cannot contain additional properties.as
(string): (optional) The name to register the pipeline result under, which can be used as source by follow-up pipelines.branch
(array): (optional) Defines a single branch, consisting of a condition and a pipeline to execute for messages that fulfil the predicate.- Items (object): Refer to #/definitions/BranchDefinitionWithPipeline.
forEach
: (optional) A function that gets called for every message in the stream.- Any of
- string
- object: Refer to #/definitions/ForEachActionDefinitionWithImplicitType.
- Any of
from
: Pipeline source.- Any of
- string
- object: Refer to #/definitions/TopicDefinitionSource.
- Any of
name
(string): (optional) The name of the operation processor.print
(object): (optional) The specification of where to print messages to. Refer to #/definitions/PrintOperation.to
: (optional) Ends the pipeline by sending all messages to a stream, table or globalTable, or to an inline defined output topic and optional partitioner.- Any of
- string
- object: Refer to #/definitions/ToTopicDefinition.
- Any of
toTopicNameExtractor
: (optional) Ends the pipeline by sending all messages to a topic provided by a pre-defined topic name extractor function, or to a topic provided by an inline defined topic name extractor and optional partitioner.- Any of
- string
- object: Refer to #/definitions/ToTopicNameExtractorDefinition.
- Any of
via
(array): (optional) A series of operations performed on the input stream.- Items
- Any of
- object: Refer to #/definitions/AggregateOperation.
- object: Refer to #/definitions/CogroupOperation.
- object: Refer to #/definitions/ConvertKeyOperation.
- object: Refer to #/definitions/ConvertKeyValueOperation.
- object: Refer to #/definitions/ConvertValueOperation.
- object: Refer to #/definitions/CountOperation.
- object: Refer to #/definitions/FilterNotOperation.
- object: Refer to #/definitions/FilterOperation.
- object: Refer to #/definitions/GroupByKeyOperation.
- object: Refer to #/definitions/GroupByOperation.
- object: Refer to #/definitions/JoinOperationWithGlobalTable.
- object: Refer to #/definitions/JoinOperationWithStream.
- object: Refer to #/definitions/JoinOperationWithTable.
- object: Refer to #/definitions/LeftJoinOperationWithGlobalTable.
- object: Refer to #/definitions/LeftJoinOperationWithStream.
- object: Refer to #/definitions/LeftJoinOperationWithTable.
- object: Refer to #/definitions/MergeOperation.
- object: Refer to #/definitions/OuterJoinOperationWithStream.
- object: Refer to #/definitions/OuterJoinOperationWithTable.
- object: Refer to #/definitions/PeekOperation.
- object: Refer to #/definitions/ReduceOperationWithAdderAndSubtractor.
- object: Refer to #/definitions/ReduceOperationWithReducer.
- object: Refer to #/definitions/RepartitionOperation.
- object: Refer to #/definitions/SuppressOperationUntilTimeLimit.
- object: Refer to #/definitions/SuppressOperationUntilWindowCloses.
- object: Refer to #/definitions/ToStreamOperation.
- object: Refer to #/definitions/ToTableOperation.
- object: Refer to #/definitions/TransformKeyOperation.
- object: Refer to #/definitions/TransformKeyValueOperation.
- object: Refer to #/definitions/TransformKeyValueToKeyValueListOperation.
- object: Refer to #/definitions/TransformKeyValueToValueListOperation.
- object: Refer to #/definitions/TransformMetadataOperation.
- object: Refer to #/definitions/TransformValueOperation.
- object: Refer to #/definitions/WindowBySessionOperation.
- object: Refer to #/definitions/WindowByTimeOperationWithHoppingWindow.
- object: Refer to #/definitions/WindowByTimeOperationWithSlidingWindow.
- object: Refer to #/definitions/WindowByTimeOperationWithTumblingWindow.
- Any of
- Items
PredicateDefinition
(object): Defines a predicate function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the predicate.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the predicate. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the predicate. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the predicate. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the predicate.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the predicate. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the predicate uses. Only required if the function wants to use a state store.- Items (string)
type
: The type of the function. Must be one of:["predicate"]
.
PredicateDefinitionWithImplicitType
(object): Defines a predicate function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the predicate.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the predicate. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the predicate. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the predicate. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the predicate.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the predicate. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the predicate uses. Only required if the function wants to use a state store.- Items (string)
PrintOperation
(object): Operation to print the contents of a pipeline on the screen or to write them to a file. Cannot contain additional properties.filename
(string): (optional) The filename to output records to. If nothing is specified, then messages will be printed on stdout.label
(string): (optional) A label to attach to the output records.mapper
: (optional) A function to convert record into a string for output.- Any of
- string
- object: Refer to #/definitions/KeyValuePrinterDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.
ProducerDefinition
(object): Definition of a Producer that regularly generates messages for a topic. Cannot contain additional properties.condition
: (optional) A function that validates the generator’s result message. Returns “true” when the message may be produced on the topic, “false” otherwise.- Any of
- string
- object: Refer to #/definitions/PredicateDefinitionWithImplicitType.
- Any of
count
: (optional) The number of messages to produce.generator
: The function that generates records.- Any of
- string
- object: Refer to #/definitions/GeneratorDefinitionWithImplicitType.
- Any of
interval
: The interval with which the generator is called.- Any of
- number
- string
- Any of
to
: The topic to produce to.- Any of
- string
- object: Refer to #/definitions/TopicDefinition.
- Any of
until
: (optional) A predicate that returns true to indicate producing should stop.- Any of
- string
- object: Refer to #/definitions/PredicateDefinitionWithImplicitType.
- Any of
ReduceOperationWithAdderAndSubtractor
(object): Operation to reduce a series of records into a single aggregate result. Cannot contain additional properties.adder
: A function that adds a record to the aggregate result.- Any of
- string
- object: Refer to #/definitions/ReducerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the aggregation.- Any of
- string
- object: Refer to #/definitions/WindowStateStoreDefinitionWithImplicitType.
- Any of
subtractor
: A function that removes a record from the aggregate result.- Any of
- string
- object: Refer to #/definitions/ReducerDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["reduce"]
.
ReduceOperationWithReducer
(object): Operation to reduce a series of records into a single aggregate result. Cannot contain additional properties.name
(string): (optional) The name of the operation processor.reducer
: A function that computes a new aggregate result.- Any of
- string
- object: Refer to #/definitions/ReducerDefinitionWithImplicitType.
- Any of
store
: (optional) Materialized view of the aggregation.- Any of
- string
- object: Refer to #/definitions/WindowStateStoreDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["reduce"]
.
ReducerDefinition
(object): Defines a reducer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the reducer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the reducer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the reducer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the reducer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the reducer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the reducer. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["reducer"]
.
ReducerDefinitionWithImplicitType
(object): Defines a reducer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the reducer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the reducer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the reducer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the reducer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the reducer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the reducer. Only required for function types, which are not pre-defined.
RepartitionOperation
(object): Operation to (re)partition a stream. Cannot contain additional properties.name
(string): (optional) The name of the operation processor.numberOfPartitions
: (optional) The target number of partitions.partitioner
: (optional) A function that partitions stream records.- Any of
- string
- object: Refer to #/definitions/StreamPartitionerDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["repartition"]
.
SessionStateStoreDefinition
(object): Definition of a session state store. Cannot contain additional properties.caching
(boolean): (optional) “true” if changed to the session store need to be buffered and periodically released, “false” to emit all changes directly.keyType
(string): (optional) The key type of the session store.logging
(boolean): (optional) “true” if a changelog topic should be set up on Kafka for this session store, “false” otherwise.name
(string): (optional) The name of the session store. If this field is not defined, then the name is derived from the context.persistent
(boolean): (optional) “true” if this session store needs to be stored on disk, “false” otherwise.retention
: (optional) The duration for which elements in the session store are retained.- Any of
- number
- string
- Any of
timestamped
(boolean): (optional) “true” if elements in the store are timestamped, “false” otherwise.type
: The type of the state store. Must be one of:["session"]
.valueType
(string): (optional) The value type of the session store.
StreamDefinition
(object): Contains a definition of a Stream, which can be referenced by producers and pipelines. Cannot contain additional properties.keyType
(string): (optional) The key type of the stream.topic
(string, required): The name of the Kafka topic for this stream.valueType
(string): (optional) The value type of the stream.
StreamDefinitionSource
(object): Contains a definition of a Stream, which can be referenced by producers and pipelines. Cannot contain additional properties.keyType
(string, required): The key type of the stream.offsetResetPolicy
(string): (optional) Policy that determines what to do when there is no initial offset in Kafka, or if the current offset does not exist any more on the server (e.g. because that data has been deleted).timestampExtractor
: (optional) A function extracts the event time from a consumed record.- Any of
- string
- object: Refer to #/definitions/TimestampExtractorDefinitionWithImplicitType.
- Any of
topic
(string, required): The name of the Kafka topic for this stream.valueType
(string, required): The value type of the stream.
StreamPartitionerDefinition
(object): Defines a stream partitioner function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the stream partitioner.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the stream partitioner. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the stream partitioner. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the stream partitioner. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the stream partitioner.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the stream partitioner. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["streamPartitioner"]
.
StreamPartitionerDefinitionWithImplicitType
(object): Defines a stream partitioner function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the stream partitioner.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the stream partitioner. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the stream partitioner. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the stream partitioner. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the stream partitioner.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the stream partitioner. Only required for function types, which are not pre-defined.
StringOrInlinePredicateDefinitionWithImplicitType
(object): Defines the condition under which messages get sent down this branch. Cannot contain additional properties.if
: (optional) Defines the condition under which messages get sent down this branch.- Any of
- string
- object: Refer to #/definitions/PredicateDefinitionWithImplicitType.
- Any of
SuppressOperationUntilTimeLimit
(object): Operation to suppress messages in the source stream until a time limit is reached. Cannot contain additional properties.bufferFullStrategy
: (optional) What to do when the buffer is full. Must be one of:["emitEarlyWhenFull", "shutdownWhenFull"]
.duration
: The duration for which messages are suppressed.- Any of
- number
- string
- Any of
maxBytes
(string): (optional) The maximum number of bytes in the buffer.maxRecords
(string): (optional) The maximum number of records in the buffer.name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["suppress"]
.until
: The until of the Operation to suppress messages in the source stream until a certain limit is reached. Must be one of:["timeLimit"]
.
SuppressOperationUntilWindowCloses
(object): Operation to suppress messages in the source stream until a window limit is reached. Cannot contain additional properties.bufferFullStrategy
: (optional) What to do when the buffer is full. Must be one of:["emitEarlyWhenFull", "shutdownWhenFull"]
.maxBytes
(string): (optional) The maximum number of bytes in the buffer.maxRecords
(string): (optional) The maximum number of records in the buffer.name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["suppress"]
.until
: The until of the Operation to suppress messages in the source stream until a certain limit is reached. Must be one of:["windowCloses"]
.
TableDefinition
(object): Contains a definition of a Table, which can be referenced by producers and pipelines. Cannot contain additional properties.keyType
(string): (optional) The key type of the table.store
: (optional) KeyValue state store definition.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
topic
(string, required): The name of the Kafka topic for this table.valueType
(string): (optional) The value type of the table.
TableDefinitionSource
(object): Contains a definition of a Table, which can be referenced by producers and pipelines. Cannot contain additional properties.keyType
(string, required): The key type of the table.offsetResetPolicy
(string): (optional) Policy that determines what to do when there is no initial offset in Kafka, or if the current offset does not exist any more on the server (e.g. because that data has been deleted).store
: (optional) KeyValue state store definition.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
timestampExtractor
: (optional) A function extracts the event time from a consumed record.- Any of
- string
- object: Refer to #/definitions/TimestampExtractorDefinitionWithImplicitType.
- Any of
topic
(string, required): The name of the Kafka topic for this table.valueType
(string, required): The value type of the table.
TimestampExtractorDefinition
(object): Defines a timestamp extractor function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the timestamp extractor.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the timestamp extractor. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the timestamp extractor. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the timestamp extractor. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the timestamp extractor.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the timestamp extractor. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["timestampExtractor"]
.
TimestampExtractorDefinitionWithImplicitType
(object): Defines a timestamp extractor function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the timestamp extractor.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the timestamp extractor. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the timestamp extractor. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the timestamp extractor. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the timestamp extractor.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the timestamp extractor. Only required for function types, which are not pre-defined.
ToStreamOperation
(object): Convert a Table into a Stream, optionally through a custom key transformer. Cannot contain additional properties.mapper
: (optional) A function that computes the output key for every record.- Any of
- string
- object: Refer to #/definitions/KeyTransformerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["toStream"]
.
ToTableOperation
(object): Convert a Stream into a Table. Cannot contain additional properties.name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the result table.- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["toTable"]
.
ToTopicDefinition
(object): Writes out pipeline messages to a topic. Cannot contain additional properties.keyType
(string): (optional) The key type of the topic.partitioner
: (optional) A function that partitions the records in the output topic.- Any of
- string
- object: Refer to #/definitions/StreamPartitionerDefinitionWithImplicitType.
- Any of
topic
(string, required): The name of the Kafka topic.valueType
(string): (optional) The value type of the topic.
ToTopicNameExtractorDefinition
(object): Writes out pipeline messages to a topic as given by a topic name extractor. Cannot contain additional properties.partitioner
: (optional) A function that partitions the records in the output topic.- Any of
- string
- object: Refer to #/definitions/StreamPartitionerDefinitionWithImplicitType.
- Any of
topicNameExtractor
: Reference to a pre-defined topic name extractor, or an inline definition of a topic name extractor.- Any of
- string
- object: Refer to #/definitions/TopicNameExtractorDefinitionWithImplicitType.
- Any of
TopicDefinition
(object): Contains a definition of a Kafka topic, to be used by producers and pipelines. Cannot contain additional properties.keyType
(string): (optional) The key type of the topic.topic
(string, required): The name of the Kafka topic.valueType
(string): (optional) The value type of the topic.
TopicDefinitionSource
(object): Contains a definition of a Kafka topic, to be used by producers and pipelines. Cannot contain additional properties.keyType
(string, required): The key type of the topic.offsetResetPolicy
(string): (optional) Policy that determines what to do when there is no initial offset in Kafka, or if the current offset does not exist any more on the server (e.g. because that data has been deleted).timestampExtractor
: (optional) A function extracts the event time from a consumed record.- Any of
- string
- object: Refer to #/definitions/TimestampExtractorDefinitionWithImplicitType.
- Any of
topic
(string, required): The name of the Kafka topic.valueType
(string, required): The value type of the topic.
TopicNameExtractorDefinition
(object): Defines a topic name extractor function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the topic name extractor.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the topic name extractor. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the topic name extractor. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the topic name extractor. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the topic name extractor.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the topic name extractor. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["topicNameExtractor"]
.
TopicNameExtractorDefinitionWithImplicitType
(object): Defines a topic name extractor function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the topic name extractor.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the topic name extractor. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the topic name extractor. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the topic name extractor. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the topic name extractor.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the topic name extractor. Only required for function types, which are not pre-defined.
TransformKeyOperation
(object): Convert the key of every record in the stream to another key. Cannot contain additional properties.mapper
: A function that computes a new key for each record.- Any of
- string
- object: Refer to #/definitions/KeyTransformerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["transformKey", "mapKey", "selectKey"]
.
TransformKeyValueOperation
(object): Convert the key/value of every record in the stream to another key/value. Cannot contain additional properties.mapper
: A function that computes a new key/value for each record.- Any of
- string
- object: Refer to #/definitions/KeyValueTransformerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["mapKeyValue", "map", "transformKeyValue"]
.
TransformKeyValueToKeyValueListOperation
(object): Convert a stream by transforming every record into a list of derived records. Cannot contain additional properties.mapper
: A function that converts every record of a stream to a list of output records.- Any of
- string
- object: Refer to #/definitions/KeyValueToKeyValueListTransformerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["transformKeyValueToKeyValueList", "flatMap"]
.
TransformKeyValueToValueListOperation
(object): Convert every record in the stream to a list of output records with the same key. Cannot contain additional properties.mapper
: A function that converts every key/value into a list of result values, each of which will be combined with the original key to form a new message in the output stream.- Any of
- string
- object: Refer to #/definitions/KeyValueToValueListTransformerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["transformKeyValueToValueList", "flatMapValues"]
.
TransformMetadataOperation
(object): Convert the metadata of every record in the stream. Cannot contain additional properties.mapper
: A function that converts the metadata (Kafka headers, timestamp) of every record in the stream.- Any of
- string
- object: Refer to #/definitions/MetadataTransformerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["transformMetadata"]
.
TransformValueOperation
(object): Convert the value of every record in the stream to another value. Cannot contain additional properties.mapper
: A function that converts the value of every record into another value.- Any of
- string
- object: Refer to #/definitions/ValueTransformerDefinitionWithImplicitType.
- Any of
name
(string): (optional) The name of the operation processor.store
: (optional) Materialized view of the transformed table (only applies to tables, ignored for streams).- Any of
- string
- object: Refer to #/definitions/KeyValueStateStoreDefinitionWithImplicitType.
- Any of
type
: The type of the operation. Must be one of:["mapValue", "transformValue", "mapValues"]
.
ValueJoinerDefinition
(object): Defines a value joiner function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the value joiner.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the value joiner. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the value joiner. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the value joiner. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the value joiner.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the value joiner. Only required for function types, which are not pre-defined.type
: The type of the function. Must be one of:["valueJoiner"]
.
ValueJoinerDefinitionWithImplicitType
(object): Defines a value joiner function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the value joiner.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the value joiner. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the value joiner. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the value joiner. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the value joiner.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the value joiner. Only required for function types, which are not pre-defined.
ValueTransformerDefinition
(object): Defines a value transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the value transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the value transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the value transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the value transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the value transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the value transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the value transformer uses. Only required if the function wants to use a state store.- Items (string)
type
: The type of the function. Must be one of:["valueTransformer"]
.
ValueTransformerDefinitionWithImplicitType
(object): Defines a value transformer function, that gets injected into the Kafka Streams topology. Cannot contain additional properties.code
: (optional) The (multiline) code of the value transformer.- Any of
- boolean
- number
- string
- Any of
expression
: (optional) The expression returned by the value transformer. Only required for functions that return values.- Any of
- boolean
- number
- string
- Any of
globalCode
: (optional) Global (multiline) code that gets loaded into the Python context outside of the value transformer. Can be used for defining eg. global variables.- Any of
- boolean
- number
- string
- Any of
name
(string): (optional) The name of the value transformer. If this field is not defined, then the name is derived from the context.parameters
(array): (optional) A list of parameters to be passed into the value transformer.- Items (object): Refer to #/definitions/ParameterDefinition.
resultType
(string): (optional) The data type returned by the value transformer. Only required for function types, which are not pre-defined.stores
(array): (optional) A list of store names that the value transformer uses. Only required if the function wants to use a state store.- Items (string)
WindowBySessionOperation
(object): Operation to window messages by session, configured by an inactivity gap. Cannot contain additional properties.grace
: (optional) (Tumbling, Hopping) The grace period, during which out-of-order records can still be processed.- Any of
- number
- string
- Any of
inactivityGap
: The inactivity gap, below which two messages are considered to be of the same session.- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["windowBySession"]
.
WindowByTimeOperationWithHoppingWindow
(object): Operation to window records based on time criteria. Cannot contain additional properties.advanceBy
: The amount of time to increase time windows by.- Any of
- number
- string
- Any of
duration
: The duration of time windows.- Any of
- number
- string
- Any of
grace
: (optional) The grace period, during which out-of-order records can still be processed.- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["windowByTime"]
.windowType
: The windowType of the time window. Must be one of:["hopping"]
.
WindowByTimeOperationWithSlidingWindow
(object): Operation to window records based on time criteria. Cannot contain additional properties.grace
: (optional) The grace period, during which out-of-order records can still be processed.- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.timeDifference
: The maximum amount of time difference between two records.- Any of
- number
- string
- Any of
type
: The type of the operation. Must be one of:["windowByTime"]
.windowType
: The windowType of the time window. Must be one of:["sliding"]
.
WindowByTimeOperationWithTumblingWindow
(object): Operation to window records based on time criteria. Cannot contain additional properties.duration
: The duration of time windows.- Any of
- number
- string
- Any of
grace
: (optional) The grace period, during which out-of-order records can still be processed.- Any of
- number
- string
- Any of
name
(string): (optional) The name of the operation processor.type
: The type of the operation. Must be one of:["windowByTime"]
.windowType
: The windowType of the time window. Must be one of:["tumbling"]
.
WindowStateStoreDefinition
(object): Definition of a window state store. Cannot contain additional properties.caching
(boolean): (optional) “true” if changed to the window store need to be buffered and periodically released, “false” to emit all changes directly.keyType
(string): (optional) The key type of the window store.logging
(boolean): (optional) “true” if a changelog topic should be set up on Kafka for this window store, “false” otherwise.name
(string): (optional) The name of the window store. If this field is not defined, then the name is derived from the context.persistent
(boolean): (optional) “true” if this window store needs to be stored on disk, “false” otherwise.retainDuplicates
(boolean): (optional) Whether or not to retain duplicates.retention
: (optional) The duration for which elements in the window store are retained.- Any of
- number
- string
- Any of
timestamped
(boolean): (optional) “true” if elements in the store are timestamped, “false” otherwise.type
: The type of the state store. Must be one of:["window"]
.valueType
(string): (optional) The value type of the window store.windowSize
: (optional) Size of the windows (cannot be negative).- Any of
- number
- string
- Any of
WindowStateStoreDefinitionWithImplicitType
(object): Definition of a window state store. Cannot contain additional properties.caching
(boolean): (optional) “true” if changed to the window store need to be buffered and periodically released, “false” to emit all changes directly.keyType
(string): (optional) The key type of the window store.logging
(boolean): (optional) “true” if a changelog topic should be set up on Kafka for this window store, “false” otherwise.name
(string): (optional) The name of the window store. If this field is not defined, then the name is derived from the context.persistent
(boolean): (optional) “true” if this window store needs to be stored on disk, “false” otherwise.retainDuplicates
(boolean): (optional) Whether or not to retain duplicates.retention
: (optional) The duration for which elements in the window store are retained.- Any of
- number
- string
- Any of
timestamped
(boolean): (optional) “true” if elements in the store are timestamped, “false” otherwise.type
: The type of the state store. Must be one of:["window"]
.valueType
(string): (optional) The value type of the window store.windowSize
: (optional) Size of the windows (cannot be negative).- Any of
- number
- string
- Any of