Interface KStreamX<K,V>
- Type Parameters:
K
- type of keysV
- type of values
- All Superinterfaces:
org.apache.kafka.streams.kstream.KStream<K,
V>
public interface KStreamX<K,V>
extends org.apache.kafka.streams.kstream.KStream<K,V>
Extends the
KStream
interface by adding methods to simplify Serde configuration, error handling, and topic
access-
Method Summary
Modifier and TypeMethodDescriptionfilter
(org.apache.kafka.streams.kstream.Predicate<? super K, ? super V> predicate, org.apache.kafka.streams.kstream.Named named) filterNot
(org.apache.kafka.streams.kstream.Predicate<? super K, ? super V> predicate, org.apache.kafka.streams.kstream.Named named) <KR,
VR> KStreamX<KR, VR> flatMap
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper) <KR,
VR> KStreamX<KR, VR> flatMap
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper, org.apache.kafka.streams.kstream.Named named) <KR,
VR> KErrorStreamX<K, V, KR, VR> flatMapCapturingErrors
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper) Transform each record of the input stream into zero or more records in the output stream.<KR,
VR> KErrorStreamX<K, V, KR, VR> flatMapCapturingErrors
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper, Predicate<Exception> errorFilter) Transform each record of the input stream into zero or more records in the output stream.<KR,
VR> KErrorStreamX<K, V, KR, VR> flatMapCapturingErrors
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Transform each record of the input stream into zero or more records in the output stream.<KR,
VR> KErrorStreamX<K, V, KR, VR> flatMapCapturingErrors
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper, org.apache.kafka.streams.kstream.Named named) Transform each record of the input stream into zero or more records in the output stream.flatMapValues
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper) flatMapValues
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) flatMapValues
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper) flatMapValues
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) <VR> KErrorStreamX<K,
V, K, VR> flatMapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.<VR> KErrorStreamX<K,
V, K, VR> flatMapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, Predicate<Exception> errorFilter) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.<VR> KErrorStreamX<K,
V, K, VR> flatMapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.<VR> KErrorStreamX<K,
V, K, VR> flatMapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.<VR> KErrorStreamX<K,
V, K, VR> flatMapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.<VR> KErrorStreamX<K,
V, K, VR> flatMapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, Predicate<Exception> errorFilter) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.<VR> KErrorStreamX<K,
V, K, VR> flatMapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.<VR> KErrorStreamX<K,
V, K, VR> flatMapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.<KR> KGroupedStreamX<KR,
V> <KR> KGroupedStreamX<KR,
V> groupBy
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, KR> keySelector, GroupedX<KR, V> grouped) <KR> KGroupedStreamX<KR,
V> groupBy
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, KR> keySelector, org.apache.kafka.streams.kstream.Grouped<KR, V> grouped) groupByKey
(GroupedX<K, V> grouped) groupByKey
(org.apache.kafka.streams.kstream.Grouped<K, V> grouped) join
(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super GV, ? extends RV> joiner) join
(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super GV, ? extends RV> joiner, org.apache.kafka.streams.kstream.Named named) join
(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> joiner) join
(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> joiner, org.apache.kafka.streams.kstream.Named named) join
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows) join
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, StreamJoinedX<K, V, VO> streamJoined) join
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) join
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows) join
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, StreamJoinedX<K, V, VO> streamJoined) join
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) join
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VT, ? extends VR> joiner) join
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VT, ? extends VR> joiner, JoinedX<K, V, VT> joined) join
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VT, ? extends VR> joiner, org.apache.kafka.streams.kstream.Joined<K, V, VT> joined) join
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner) join
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, JoinedX<K, V, VT> joined) join
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, org.apache.kafka.streams.kstream.Joined<K, V, VT> joined) leftJoin
(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super GV, ? extends RV> valueJoiner) leftJoin
(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super GV, ? extends RV> valueJoiner, org.apache.kafka.streams.kstream.Named named) leftJoin
(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> valueJoiner) leftJoin
(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> valueJoiner, org.apache.kafka.streams.kstream.Named named) leftJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows) leftJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, StreamJoinedX<K, V, VO> streamJoined) leftJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) leftJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows) leftJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, StreamJoinedX<K, V, VO> streamJoined) leftJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) leftJoin
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VT, ? extends VR> joiner) leftJoin
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VT, ? extends VR> joiner, JoinedX<K, V, VT> joined) leftJoin
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VT, ? extends VR> joiner, org.apache.kafka.streams.kstream.Joined<K, V, VT> joined) leftJoin
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner) leftJoin
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, JoinedX<K, V, VT> joined) leftJoin
(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, org.apache.kafka.streams.kstream.Joined<K, V, VT> joined) <KR,
VR> KStreamX<KR, VR> map
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper) <KR,
VR> KStreamX<KR, VR> map
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) <KR,
VR> KErrorStreamX<K, V, KR, VR> mapCapturingErrors
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper) Transform each record of the input stream into a new record in the output stream.<KR,
VR> KErrorStreamX<K, V, KR, VR> mapCapturingErrors
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper, Predicate<Exception> errorFilter) Transform each record of the input stream into a new record in the output stream.<KR,
VR> KErrorStreamX<K, V, KR, VR> mapCapturingErrors
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Transform each record of the input stream into a new record in the output stream.<KR,
VR> KErrorStreamX<K, V, KR, VR> mapCapturingErrors
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) Transform each record of the input stream into a new record in the output stream.mapValues
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper, org.apache.kafka.streams.kstream.Named named) mapValues
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper) mapValues
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, org.apache.kafka.streams.kstream.Named named) <VR> KErrorStreamX<K,
V, K, VR> mapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper) Transform the value of each input record into a new value of the output record.<VR> KErrorStreamX<K,
V, K, VR> mapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper, Predicate<Exception> errorFilter) Transform the value of each input record into a new value of the output record.<VR> KErrorStreamX<K,
V, K, VR> mapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Transform the value of each input record into a new value of the output record.<VR> KErrorStreamX<K,
V, K, VR> mapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper, org.apache.kafka.streams.kstream.Named named) Transform the value of each input record into a new value of the output record.<VR> KErrorStreamX<K,
V, K, VR> mapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper) Transform the value of each input record into a new value of the output record.<VR> KErrorStreamX<K,
V, K, VR> mapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, Predicate<Exception> errorFilter) Transform the value of each input record into a new value of the output record.<VR> KErrorStreamX<K,
V, K, VR> mapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Transform the value of each input record into a new value of the output record.<VR> KErrorStreamX<K,
V, K, VR> mapValuesCapturingErrors
(org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, org.apache.kafka.streams.kstream.Named named) Transform the value of each input record into a new value of the output record.merge
(org.apache.kafka.streams.kstream.KStream<K, V> stream, org.apache.kafka.streams.kstream.Named named) outerJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows) outerJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, StreamJoinedX<K, V, VO> streamJoined) outerJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) outerJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows) outerJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, StreamJoinedX<K, V, VO> streamJoined) outerJoin
(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) peek
(org.apache.kafka.streams.kstream.ForeachAction<? super K, ? super V> action, org.apache.kafka.streams.kstream.Named named) <KOut,
VOut>
KStreamX<KOut,VOut> process
(org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, String... stateStoreNames) <KOut,
VOut>
KStreamX<KOut,VOut> process
(org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) <KOut,
VOut>
KErrorStreamX<K,V, KOut, VOut> processCapturingErrors
(org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
.<KOut,
VOut>
KErrorStreamX<K,V, KOut, VOut> processCapturingErrors
(org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, Predicate<Exception> errorFilter, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
.<KOut,
VOut>
KErrorStreamX<K,V, KOut, VOut> processCapturingErrors
(org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
.<KOut,
VOut>
KErrorStreamX<K,V, KOut, VOut> processCapturingErrors
(org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
.processValues
(org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, String... stateStoreNames) processValues
(org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) <VOut> KErrorStreamX<K,
V, K, VOut> processValuesCapturingErrors
(org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
.<VOut> KErrorStreamX<K,
V, K, VOut> processValuesCapturingErrors
(org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, Predicate<Exception> errorFilter, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
.<VOut> KErrorStreamX<K,
V, K, VOut> processValuesCapturingErrors
(org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
.<VOut> KErrorStreamX<K,
V, K, VOut> processValuesCapturingErrors
(org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
.repartition
(RepartitionedX<K, V> repartitioned) repartition
(org.apache.kafka.streams.kstream.Repartitioned<K, V> repartitioned) selectKey
(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends KR> mapper, org.apache.kafka.streams.kstream.Named named) split()
split
(org.apache.kafka.streams.kstream.Named named) void
void
to
(org.apache.kafka.streams.processor.TopicNameExtractor<K, V> topicExtractor, ProducedX<K, V> produced) void
MaterializeKStream
toStreamsTopicConfig.getErrorTopic()
void
toErrorTopic
(ProducedX<K, V> produced) MaterializeKStream
toStreamsTopicConfig.getErrorTopic()
void
toErrorTopic
(org.apache.kafka.streams.kstream.Produced<K, V> produced) MaterializeKStream
toStreamsTopicConfig.getErrorTopic()
void
MaterializeKStream
toStreamsTopicConfig.getOutputTopic()
void
toOutputTopic
(ProducedX<K, V> produced) MaterializeKStream
toStreamsTopicConfig.getOutputTopic()
void
toOutputTopic
(String label) MaterializeKStream
toStreamsTopicConfig.getOutputTopic(String)
void
toOutputTopic
(String label, ProducedX<K, V> produced) MaterializeKStream
toStreamsTopicConfig.getOutputTopic(String)
void
toOutputTopic
(String label, org.apache.kafka.streams.kstream.Produced<K, V> produced) MaterializeKStream
toStreamsTopicConfig.getOutputTopic(String)
void
toOutputTopic
(org.apache.kafka.streams.kstream.Produced<K, V> produced) MaterializeKStream
toStreamsTopicConfig.getOutputTopic()
toTable()
toTable
(MaterializedX<K, V, org.apache.kafka.streams.state.KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) toTable
(org.apache.kafka.streams.kstream.Materialized<K, V, org.apache.kafka.streams.state.KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) toTable
(org.apache.kafka.streams.kstream.Named named) toTable
(org.apache.kafka.streams.kstream.Named named, MaterializedX<K, V, org.apache.kafka.streams.state.KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) toTable
(org.apache.kafka.streams.kstream.Named named, org.apache.kafka.streams.kstream.Materialized<K, V, org.apache.kafka.streams.state.KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) Methods inherited from interface org.apache.kafka.streams.kstream.KStream
foreach, foreach, print, to, to, to, to
-
Method Details
-
filter
-
filter
-
filterNot
-
filterNot
-
selectKey
-
selectKey
-
map
-
mapCapturingErrors
<KR,VR> KErrorStreamX<K,V, mapCapturingErrorsKR, VR> (org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper) Transform each record of the input stream into a new record in the output stream. Errors in the mapper are captured- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes a new output record- Returns:
- a
KErrorStreamX
that contains records with new key and value as well as captured errors - See Also:
-
map(KeyValueMapper)
ErrorCapturingKeyValueMapper.captureErrors(KeyValueMapper)
-
mapCapturingErrors
<KR,VR> KErrorStreamX<K,V, mapCapturingErrorsKR, VR> (org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper, Predicate<Exception> errorFilter) Transform each record of the input stream into a new record in the output stream. Errors in the mapper are captured- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes a new output recorderrorFilter
- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamX
that contains records with new key and value as well as captured errors - See Also:
-
map(KeyValueMapper)
ErrorCapturingKeyValueMapper.captureErrors(KeyValueMapper, java.util.function.Predicate)
-
map
-
mapCapturingErrors
<KR,VR> KErrorStreamX<K,V, mapCapturingErrorsKR, VR> (org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) Transform each record of the input stream into a new record in the output stream. Errors in the mapper are captured- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes a new output recordnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains records with new key and value as well as captured errors - See Also:
-
map(KeyValueMapper, Named)
ErrorCapturingKeyValueMapper.captureErrors(KeyValueMapper)
-
mapCapturingErrors
<KR,VR> KErrorStreamX<K,V, mapCapturingErrorsKR, VR> (org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Transform each record of the input stream into a new record in the output stream. Errors in the mapper are captured- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes a new output recorderrorFilter
- expression that filters errors which should be thrown and not capturednamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains records with new key and value as well as captured errors - See Also:
-
map(KeyValueMapper, Named)
ErrorCapturingKeyValueMapper.captureErrors(KeyValueMapper, java.util.function.Predicate)
-
mapValues
-
mapValuesCapturingErrors
<VR> KErrorStreamX<K,V, mapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper) Transform the value of each input record into a new value of the output record. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes a new output value- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
mapValues(ValueMapper)
ErrorCapturingValueMapper.captureErrors(ValueMapper)
-
mapValuesCapturingErrors
<VR> KErrorStreamX<K,V, mapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper, Predicate<Exception> errorFilter) Transform the value of each input record into a new value of the output record. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes a new output valueerrorFilter
- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
mapValues(ValueMapper)
ErrorCapturingValueMapper.captureErrors(ValueMapper, java.util.function.Predicate)
-
mapValues
-
mapValuesCapturingErrors
<VR> KErrorStreamX<K,V, mapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper, org.apache.kafka.streams.kstream.Named named) Transform the value of each input record into a new value of the output record. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes a new output valuenamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
mapValues(ValueMapper, Named)
ErrorCapturingValueMapper.captureErrors(ValueMapper)
-
mapValuesCapturingErrors
<VR> KErrorStreamX<K,V, mapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends VR> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Transform the value of each input record into a new value of the output record. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes a new output valueerrorFilter
- expression that filters errors which should be thrown and not capturednamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
mapValues(ValueMapper, Named)
ErrorCapturingValueMapper.captureErrors(ValueMapper, java.util.function.Predicate)
-
mapValues
-
mapValuesCapturingErrors
<VR> KErrorStreamX<K,V, mapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper) Transform the value of each input record into a new value of the output record. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes a new output value- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
mapValues(ValueMapperWithKey)
ErrorCapturingValueMapperWithKey.captureErrors(ValueMapperWithKey)
-
mapValuesCapturingErrors
<VR> KErrorStreamX<K,V, mapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, Predicate<Exception> errorFilter) Transform the value of each input record into a new value of the output record. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes a new output valueerrorFilter
- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
mapValues(ValueMapperWithKey)
ErrorCapturingValueMapperWithKey.captureErrors(ValueMapperWithKey, java.util.function.Predicate)
-
mapValues
-
mapValuesCapturingErrors
<VR> KErrorStreamX<K,V, mapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, org.apache.kafka.streams.kstream.Named named) Transform the value of each input record into a new value of the output record. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes a new output valuenamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
mapValues(ValueMapperWithKey, Named)
ErrorCapturingValueMapperWithKey.captureErrors(ValueMapperWithKey)
-
mapValuesCapturingErrors
<VR> KErrorStreamX<K,V, mapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Transform the value of each input record into a new value of the output record. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes a new output valueerrorFilter
- expression that filters errors which should be thrown and not capturednamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
mapValues(ValueMapperWithKey, Named)
ErrorCapturingValueMapperWithKey.captureErrors(ValueMapperWithKey, java.util.function.Predicate)
-
flatMap
-
flatMapCapturingErrors
<KR,VR> KErrorStreamX<K,V, flatMapCapturingErrorsKR, VR> (org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper) Transform each record of the input stream into zero or more records in the output stream. Errors in the mapper are captured- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes the new output records- Returns:
- a
KErrorStreamX
that contains more or less records with new key and value as well as captured errors - See Also:
-
flatMap(KeyValueMapper)
ErrorCapturingFlatKeyValueMapper.captureErrors(KeyValueMapper)
-
flatMapCapturingErrors
<KR,VR> KErrorStreamX<K,V, flatMapCapturingErrorsKR, VR> (org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper, Predicate<Exception> errorFilter) Transform each record of the input stream into zero or more records in the output stream. Errors in the mapper are captured- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes the new output recordserrorFilter
- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamX
that contains more or less records with new key and value as well as captured errors - See Also:
-
flatMap(KeyValueMapper)
ErrorCapturingFlatKeyValueMapper.captureErrors(KeyValueMapper, java.util.function.Predicate)
-
flatMap
-
flatMapCapturingErrors
<KR,VR> KErrorStreamX<K,V, flatMapCapturingErrorsKR, VR> (org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper, org.apache.kafka.streams.kstream.Named named) Transform each record of the input stream into zero or more records in the output stream. Errors in the mapper are captured- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes the new output recordsnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains more or less records with new key and value as well as captured errors - See Also:
-
flatMap(KeyValueMapper, Named)
ErrorCapturingFlatKeyValueMapper.captureErrors(KeyValueMapper)
-
flatMapCapturingErrors
<KR,VR> KErrorStreamX<K,V, flatMapCapturingErrorsKR, VR> (org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends org.apache.kafka.streams.KeyValue<? extends KR, ? extends VR>>> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Transform each record of the input stream into zero or more records in the output stream. Errors in the mapper are captured- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes the new output recordserrorFilter
- expression that filters errors which should be thrown and not capturednamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains more or less records with new key and value as well as captured errors - See Also:
-
flatMap(KeyValueMapper, Named)
ErrorCapturingFlatKeyValueMapper.captureErrors(KeyValueMapper, java.util.function.Predicate)
-
flatMapValues
-
flatMapValuesCapturingErrors
<VR> KErrorStreamX<K,V, flatMapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes the new output values- Returns:
- a
KErrorStreamX
that contains more or less records with unmodified keys and new values as well as captured errors - See Also:
-
flatMapValues(ValueMapper)
ErrorCapturingFlatValueMapper.captureErrors(ValueMapper)
-
flatMapValuesCapturingErrors
<VR> KErrorStreamX<K,V, flatMapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, Predicate<Exception> errorFilter) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes the new output valueserrorFilter
- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamX
that contains more or less records with unmodified keys and new values as well as captured errors - See Also:
-
flatMapValues(ValueMapper)
ErrorCapturingFlatValueMapper.captureErrors(ValueMapper, java.util.function.Predicate)
-
flatMapValues
-
flatMapValuesCapturingErrors
<VR> KErrorStreamX<K,V, flatMapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes the new output valuesnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains more or less records with unmodified keys and new values as well as captured errors - See Also:
-
flatMapValues(ValueMapper, Named)
ErrorCapturingFlatValueMapper.captureErrors(ValueMapper)
-
flatMapValuesCapturingErrors
<VR> KErrorStreamX<K,V, flatMapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes the new output valueserrorFilter
- expression that filters errors which should be thrown and not capturednamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains more or less records with unmodified keys and new values as well as captured errors - See Also:
-
flatMapValues(ValueMapper, Named)
ErrorCapturingFlatValueMapper.captureErrors(ValueMapper, java.util.function.Predicate)
-
flatMapValues
-
flatMapValuesCapturingErrors
<VR> KErrorStreamX<K,V, flatMapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes the new output values- Returns:
- a
KErrorStreamX
that contains more or less records with unmodified keys and new values as well as captured errors - See Also:
-
flatMapValues(ValueMapperWithKey)
ErrorCapturingFlatValueMapperWithKey.captureErrors(ValueMapperWithKey)
-
flatMapValuesCapturingErrors
<VR> KErrorStreamX<K,V, flatMapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, Predicate<Exception> errorFilter) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes the new output valueserrorFilter
- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamX
that contains more or less records with unmodified keys and new values as well as captured errors - See Also:
-
flatMapValues(ValueMapperWithKey)
ErrorCapturingFlatValueMapperWithKey.captureErrors(ValueMapperWithKey, java.util.function.Predicate)
-
flatMapValues
-
flatMapValuesCapturingErrors
<VR> KErrorStreamX<K,V, flatMapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, org.apache.kafka.streams.kstream.Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes the new output valuesnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains more or less records with unmodified keys and new values as well as captured errors - See Also:
-
flatMapValues(ValueMapperWithKey, Named)
ErrorCapturingFlatValueMapperWithKey.captureErrors(ValueMapperWithKey)
-
flatMapValuesCapturingErrors
<VR> KErrorStreamX<K,V, flatMapValuesCapturingErrorsK, VR> (org.apache.kafka.streams.kstream.ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Errors in the mapper are captured- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes the new output valueserrorFilter
- expression that filters errors which should be thrown and not capturednamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KErrorStreamX
that contains more or less records with unmodified keys and new values as well as captured errors - See Also:
-
flatMapValues(ValueMapperWithKey, Named)
ErrorCapturingFlatValueMapperWithKey.captureErrors(ValueMapperWithKey, java.util.function.Predicate)
-
peek
-
peek
-
split
BranchedKStreamX<K,V> split() -
split
-
merge
-
merge
-
repartition
-
repartition
-
repartition
- See Also:
-
to
- See Also:
-
KStream.to(String, Produced)
-
to
void to(org.apache.kafka.streams.processor.TopicNameExtractor<K, V> topicExtractor, ProducedX<K, V> produced) - See Also:
-
KStream.to(TopicNameExtractor, Produced)
-
toOutputTopic
void toOutputTopic()MaterializeKStream
toStreamsTopicConfig.getOutputTopic()
- See Also:
-
KStream.to(String)
-
toOutputTopic
MaterializeKStream
toStreamsTopicConfig.getOutputTopic()
- Parameters:
produced
- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toOutputTopic
MaterializeKStream
toStreamsTopicConfig.getOutputTopic()
- Parameters:
produced
- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toOutputTopic
MaterializeKStream
toStreamsTopicConfig.getOutputTopic(String)
- Parameters:
label
- label of output topic- See Also:
-
KStream.to(String)
-
toOutputTopic
MaterializeKStream
toStreamsTopicConfig.getOutputTopic(String)
- Parameters:
label
- label of output topicproduced
- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toOutputTopic
MaterializeKStream
toStreamsTopicConfig.getOutputTopic(String)
- Parameters:
label
- label of output topicproduced
- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toErrorTopic
void toErrorTopic()MaterializeKStream
toStreamsTopicConfig.getErrorTopic()
- See Also:
-
KStream.to(String)
-
toErrorTopic
MaterializeKStream
toStreamsTopicConfig.getErrorTopic()
- Parameters:
produced
- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toErrorTopic
MaterializeKStream
toStreamsTopicConfig.getErrorTopic()
- Parameters:
produced
- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toTable
-
toTable
-
toTable
-
toTable
KTableX<K,V> toTable(MaterializedX<K, V, org.apache.kafka.streams.state.KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) - See Also:
-
toTable
-
toTable
KTableX<K,V> toTable(org.apache.kafka.streams.kstream.Named named, MaterializedX<K, V, org.apache.kafka.streams.state.KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) - See Also:
-
groupBy
<KR> KGroupedStreamX<KR,V> groupBy(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, KR> keySelector) -
groupBy
<KR> KGroupedStreamX<KR,V> groupBy(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, KR> keySelector, org.apache.kafka.streams.kstream.Grouped<KR, V> grouped) -
groupBy
<KR> KGroupedStreamX<KR,V> groupBy(org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, KR> keySelector, GroupedX<KR, V> grouped) - See Also:
-
groupByKey
KGroupedStreamX<K,V> groupByKey() -
groupByKey
-
groupByKey
- See Also:
-
join
-
join
-
join
-
join
-
join
<VO,VR> KStreamX<K,VR> join(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) -
join
-
leftJoin
-
leftJoin
-
leftJoin
<VO,VR> KStreamX<K,VR> leftJoin(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) -
leftJoin
-
leftJoin
<VO,VR> KStreamX<K,VR> leftJoin(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) -
leftJoin
-
outerJoin
-
outerJoin
-
outerJoin
<VO,VR> KStreamX<K,VR> outerJoin(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) -
outerJoin
-
outerJoin
<VO,VR> KStreamX<K,VR> outerJoin(org.apache.kafka.streams.kstream.KStream<K, VO> otherStream, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, org.apache.kafka.streams.kstream.JoinWindows windows, org.apache.kafka.streams.kstream.StreamJoined<K, V, VO> streamJoined) -
outerJoin
-
join
-
join
-
join
-
join
<VT,VR> KStreamX<K,VR> join(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VT, ? extends VR> joiner, JoinedX<K, V, VT> joined) - See Also:
-
join
-
join
<VT,VR> KStreamX<K,VR> join(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, JoinedX<K, V, VT> joined) - See Also:
-
leftJoin
-
leftJoin
-
leftJoin
-
leftJoin
<VT,VR> KStreamX<K,VR> leftJoin(org.apache.kafka.streams.kstream.KTable<K, VT> table, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VT, ? extends VR> joiner, JoinedX<K, V, VT> joined) - See Also:
-
leftJoin
-
leftJoin
-
join
-
join
-
join
<GK,GV, KStreamX<K,RV> RV> join(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super GV, ? extends RV> joiner, org.apache.kafka.streams.kstream.Named named) -
join
<GK,GV, KStreamX<K,RV> RV> join(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> joiner, org.apache.kafka.streams.kstream.Named named) -
leftJoin
-
leftJoin
<GK,GV, KStreamX<K,RV> RV> leftJoin(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> valueJoiner) -
leftJoin
<GK,GV, KStreamX<K,RV> RV> leftJoin(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super GV, ? extends RV> valueJoiner, org.apache.kafka.streams.kstream.Named named) -
leftJoin
<GK,GV, KStreamX<K,RV> RV> leftJoin(org.apache.kafka.streams.kstream.GlobalKTable<GK, GV> globalTable, org.apache.kafka.streams.kstream.KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, org.apache.kafka.streams.kstream.ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> valueJoiner, org.apache.kafka.streams.kstream.Named named) -
process
-
processCapturingErrors
<KOut,VOut> KErrorStreamX<K,V, processCapturingErrorsKOut, VOut> (org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
. Errors in the mapper are captured- Type Parameters:
KOut
- the key type of the result streamVOut
- the value type of the result stream- Parameters:
processorSupplier
- an instance ofProcessorSupplier
that generates a newly constructedProcessor
stateStoreNames
- the names of the state store used by the processor- Returns:
- a
KErrorStreamX
that contains records with new key and value as well as captured errors - See Also:
-
process(ProcessorSupplier, String...)
ErrorCapturingProcessor.captureErrors(ProcessorSupplier)
-
processCapturingErrors
<KOut,VOut> KErrorStreamX<K,V, processCapturingErrorsKOut, VOut> (org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, Predicate<Exception> errorFilter, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
. Errors in the mapper are captured- Type Parameters:
KOut
- the key type of the result streamVOut
- the value type of the result stream- Parameters:
processorSupplier
- an instance ofProcessorSupplier
that generates a newly constructedProcessor
errorFilter
- expression that filters errors which should be thrown and not capturedstateStoreNames
- the names of the state store used by the processor- Returns:
- a
KErrorStreamX
that contains records with new key and value as well as captured errors - See Also:
-
process(ProcessorSupplier, String...)
ErrorCapturingProcessor.captureErrors(ProcessorSupplier, java.util.function.Predicate)
-
process
-
processCapturingErrors
<KOut,VOut> KErrorStreamX<K,V, processCapturingErrorsKOut, VOut> (org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
. Errors in the mapper are captured- Type Parameters:
KOut
- the key type of the result streamVOut
- the value type of the result stream- Parameters:
processorSupplier
- an instance ofProcessorSupplier
that generates a newly constructedProcessor
named
- aNamed
config used to name the processor in the topologystateStoreNames
- the names of the state store used by the processor- Returns:
- a
KErrorStreamX
that contains records with new key and value as well as captured errors - See Also:
-
process(ProcessorSupplier, Named, String...)
ErrorCapturingProcessor.captureErrors(ProcessorSupplier)
-
processCapturingErrors
<KOut,VOut> KErrorStreamX<K,V, processCapturingErrorsKOut, VOut> (org.apache.kafka.streams.processor.api.ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
. Errors in the mapper are captured- Type Parameters:
KOut
- the key type of the result streamVOut
- the value type of the result stream- Parameters:
processorSupplier
- an instance ofProcessorSupplier
that generates a newly constructedProcessor
errorFilter
- expression that filters errors which should be thrown and not capturednamed
- aNamed
config used to name the processor in the topologystateStoreNames
- the names of the state store used by the processor- Returns:
- a
KErrorStreamX
that contains records with new key and value as well as captured errors - See Also:
-
process(ProcessorSupplier, Named, String...)
ErrorCapturingProcessor.captureErrors(ProcessorSupplier, java.util.function.Predicate)
-
processValues
-
processValuesCapturingErrors
<VOut> KErrorStreamX<K,V, processValuesCapturingErrorsK, VOut> (org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
. Errors in the mapper are captured- Type Parameters:
VOut
- the value type of the result stream- Parameters:
processorSupplier
- an instance ofFixedKeyProcessorSupplier
that generates a newly constructedFixedKeyProcessor
stateStoreNames
- the names of the state store used by the processor- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
processValues(FixedKeyProcessorSupplier, String...)
ErrorCapturingValueProcessor.captureErrors(FixedKeyProcessorSupplier)
-
processValuesCapturingErrors
<VOut> KErrorStreamX<K,V, processValuesCapturingErrorsK, VOut> (org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, Predicate<Exception> errorFilter, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
. Errors in the mapper are captured- Type Parameters:
VOut
- the value type of the result stream- Parameters:
processorSupplier
- an instance ofFixedKeyProcessorSupplier
that generates a newly constructedFixedKeyProcessor
errorFilter
- expression that filters errors which should be thrown and not capturedstateStoreNames
- the names of the state store used by the processor- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
processValues(FixedKeyProcessorSupplier, String...)
ErrorCapturingValueProcessor.captureErrors(FixedKeyProcessorSupplier, java.util.function.Predicate)
-
processValues
-
processValuesCapturingErrors
<VOut> KErrorStreamX<K,V, processValuesCapturingErrorsK, VOut> (org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
. Errors in the mapper are captured- Type Parameters:
VOut
- the value type of the result stream- Parameters:
processorSupplier
- an instance ofFixedKeyProcessorSupplier
that generates a newly constructedFixedKeyProcessor
named
- aNamed
config used to name the processor in the topologystateStoreNames
- the names of the state store used by the processor- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
processValues(FixedKeyProcessorSupplier, Named, String...)
ErrorCapturingValueProcessor.captureErrors(FixedKeyProcessorSupplier)
-
processValuesCapturingErrors
<VOut> KErrorStreamX<K,V, processValuesCapturingErrorsK, VOut> (org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, Predicate<Exception> errorFilter, org.apache.kafka.streams.kstream.Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
. Errors in the mapper are captured- Type Parameters:
VOut
- the value type of the result stream- Parameters:
processorSupplier
- an instance ofFixedKeyProcessorSupplier
that generates a newly constructedFixedKeyProcessor
errorFilter
- expression that filters errors which should be thrown and not capturednamed
- aNamed
config used to name the processor in the topologystateStoreNames
- the names of the state store used by the processor- Returns:
- a
KErrorStreamX
that contains records with unmodified key and new values as well as captured errors - See Also:
-
processValues(FixedKeyProcessorSupplier, Named, String...)
ErrorCapturingValueProcessor.captureErrors(FixedKeyProcessorSupplier, java.util.function.Predicate)
-