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 newKStreamby 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 newKStreamby 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 newKStreamby 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 newKStreamby 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 newKStreamby 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 newKStreamby 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 newKStreamby 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 newKStreamby 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) voidvoidto(org.apache.kafka.streams.processor.TopicNameExtractor<K, V> topicExtractor, ProducedX<K, V> produced) voidMaterializeKStreamtoStreamsTopicConfig.getErrorTopic()voidtoErrorTopic(ProducedX<K, V> produced) MaterializeKStreamtoStreamsTopicConfig.getErrorTopic()voidtoErrorTopic(org.apache.kafka.streams.kstream.Produced<K, V> produced) MaterializeKStreamtoStreamsTopicConfig.getErrorTopic()voidMaterializeKStreamtoStreamsTopicConfig.getOutputTopic()voidtoOutputTopic(ProducedX<K, V> produced) MaterializeKStreamtoStreamsTopicConfig.getOutputTopic()voidtoOutputTopic(String label) MaterializeKStreamtoStreamsTopicConfig.getOutputTopic(String)voidtoOutputTopic(String label, ProducedX<K, V> produced) MaterializeKStreamtoStreamsTopicConfig.getOutputTopic(String)voidtoOutputTopic(String label, org.apache.kafka.streams.kstream.Produced<K, V> produced) MaterializeKStreamtoStreamsTopicConfig.getOutputTopic(String)voidtoOutputTopic(org.apache.kafka.streams.kstream.Produced<K, V> produced) MaterializeKStreamtoStreamsTopicConfig.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- aKeyValueMapperthat computes a new output record- Returns:
- a
KErrorStreamXthat 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- aKeyValueMapperthat computes a new output recorderrorFilter- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamXthat 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- aKeyValueMapperthat computes a new output recordnamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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- aKeyValueMapperthat computes a new output recorderrorFilter- expression that filters errors which should be thrown and not capturednamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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- aValueMapperthat computes a new output value- Returns:
- a
KErrorStreamXthat 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- aValueMapperthat computes a new output valueerrorFilter- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamXthat 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- aValueMapperthat computes a new output valuenamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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- aValueMapperthat computes a new output valueerrorFilter- expression that filters errors which should be thrown and not capturednamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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- aValueMapperWithKeythat computes a new output value- Returns:
- a
KErrorStreamXthat 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- aValueMapperWithKeythat computes a new output valueerrorFilter- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamXthat 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- aValueMapperWithKeythat computes a new output valuenamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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- aValueMapperWithKeythat computes a new output valueerrorFilter- expression that filters errors which should be thrown and not capturednamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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- aKeyValueMapperthat computes the new output records- Returns:
- a
KErrorStreamXthat 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- aKeyValueMapperthat computes the new output recordserrorFilter- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamXthat 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- aKeyValueMapperthat computes the new output recordsnamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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- aKeyValueMapperthat computes the new output recordserrorFilter- expression that filters errors which should be thrown and not capturednamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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 newKStreamby 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- aValueMapperthat computes the new output values- Returns:
- a
KErrorStreamXthat 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 newKStreamby 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- aValueMapperthat computes the new output valueserrorFilter- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamXthat 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 newKStreamby 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- aValueMapperthat computes the new output valuesnamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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 newKStreamby 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- aValueMapperthat computes the new output valueserrorFilter- expression that filters errors which should be thrown and not capturednamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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 newKStreamby 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- aValueMapperWithKeythat computes the new output values- Returns:
- a
KErrorStreamXthat 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 newKStreamby 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- aValueMapperWithKeythat computes the new output valueserrorFilter- expression that filters errors which should be thrown and not captured- Returns:
- a
KErrorStreamXthat 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 newKStreamby 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- aValueMapperWithKeythat computes the new output valuesnamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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 newKStreamby 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- aValueMapperWithKeythat computes the new output valueserrorFilter- expression that filters errors which should be thrown and not capturednamed- aNamedconfig used to name the processor in the topology- Returns:
- a
KErrorStreamXthat 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()MaterializeKStreamtoStreamsTopicConfig.getOutputTopic()- See Also:
-
KStream.to(String)
-
toOutputTopic
MaterializeKStreamtoStreamsTopicConfig.getOutputTopic()- Parameters:
produced- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toOutputTopic
MaterializeKStreamtoStreamsTopicConfig.getOutputTopic()- Parameters:
produced- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toOutputTopic
MaterializeKStreamtoStreamsTopicConfig.getOutputTopic(String)- Parameters:
label- label of output topic- See Also:
-
KStream.to(String)
-
toOutputTopic
MaterializeKStreamtoStreamsTopicConfig.getOutputTopic(String)- Parameters:
label- label of output topicproduced- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toOutputTopic
MaterializeKStreamtoStreamsTopicConfig.getOutputTopic(String)- Parameters:
label- label of output topicproduced- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toErrorTopic
void toErrorTopic()MaterializeKStreamtoStreamsTopicConfig.getErrorTopic()- See Also:
-
KStream.to(String)
-
toErrorTopic
MaterializeKStreamtoStreamsTopicConfig.getErrorTopic()- Parameters:
produced- define optional parameters for materializing the stream- See Also:
-
KStream.to(String, Produced)
-
toErrorTopic
MaterializeKStreamtoStreamsTopicConfig.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 ofProcessorSupplierthat generates a newly constructedProcessorstateStoreNames- the names of the state store used by the processor- Returns:
- a
KErrorStreamXthat 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 ofProcessorSupplierthat generates a newly constructedProcessorerrorFilter- expression that filters errors which should be thrown and not capturedstateStoreNames- the names of the state store used by the processor- Returns:
- a
KErrorStreamXthat 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 ofProcessorSupplierthat generates a newly constructedProcessornamed- aNamedconfig used to name the processor in the topologystateStoreNames- the names of the state store used by the processor- Returns:
- a
KErrorStreamXthat 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 ofProcessorSupplierthat generates a newly constructedProcessorerrorFilter- expression that filters errors which should be thrown and not capturednamed- aNamedconfig used to name the processor in the topologystateStoreNames- the names of the state store used by the processor- Returns:
- a
KErrorStreamXthat 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 ofFixedKeyProcessorSupplierthat generates a newly constructedFixedKeyProcessorstateStoreNames- the names of the state store used by the processor- Returns:
- a
KErrorStreamXthat 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 ofFixedKeyProcessorSupplierthat generates a newly constructedFixedKeyProcessorerrorFilter- expression that filters errors which should be thrown and not capturedstateStoreNames- the names of the state store used by the processor- Returns:
- a
KErrorStreamXthat 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 ofFixedKeyProcessorSupplierthat generates a newly constructedFixedKeyProcessornamed- aNamedconfig used to name the processor in the topologystateStoreNames- the names of the state store used by the processor- Returns:
- a
KErrorStreamXthat 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 ofFixedKeyProcessorSupplierthat generates a newly constructedFixedKeyProcessorerrorFilter- expression that filters errors which should be thrown and not capturednamed- aNamedconfig used to name the processor in the topologystateStoreNames- the names of the state store used by the processor- Returns:
- a
KErrorStreamXthat 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)
-