You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by mj...@apache.org on 2022/12/27 23:38:55 UTC

[kafka] branch 3.4 updated: KAFKA-13881: Add Streams package infos (#12936)

This is an automated email from the ASF dual-hosted git repository.

mjsax pushed a commit to branch 3.4
in repository https://gitbox.apache.org/repos/asf/kafka.git


The following commit(s) were added to refs/heads/3.4 by this push:
     new 4c42a91cfce KAFKA-13881: Add Streams package infos (#12936)
4c42a91cfce is described below

commit 4c42a91cfcedcf96c4e57fd127e5cc2a0c0fb895
Author: Greg Harris <gr...@aiven.io>
AuthorDate: Tue Dec 27 15:37:25 2022 -0800

    KAFKA-13881: Add Streams package infos (#12936)
    
    Reviewers: Christo Lolov (@clolov), Matthias J. Sax <ma...@confluent.io>
---
 .../apache/kafka/streams/errors/package-info.java   | 20 ++++++++++++++++++++
 .../apache/kafka/streams/kstream/package-info.java  | 21 +++++++++++++++++++++
 .../java/org/apache/kafka/streams/package-info.java | 20 ++++++++++++++++++++
 .../kafka/streams/processor/api/package-info.java   | 21 +++++++++++++++++++++
 .../kafka/streams/processor/package-info.java       | 21 +++++++++++++++++++++
 .../apache/kafka/streams/query/package-info.java    | 20 ++++++++++++++++++++
 .../apache/kafka/streams/state/package-info.java    | 20 ++++++++++++++++++++
 .../org/apache/kafka/streams/test/package-info.java | 20 ++++++++++++++++++++
 8 files changed, 163 insertions(+)

diff --git a/streams/src/main/java/org/apache/kafka/streams/errors/package-info.java b/streams/src/main/java/org/apache/kafka/streams/errors/package-info.java
new file mode 100644
index 00000000000..e8b1a3ae949
--- /dev/null
+++ b/streams/src/main/java/org/apache/kafka/streams/errors/package-info.java
@@ -0,0 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Provides common exception classes for Streams applications.
+ */
+package org.apache.kafka.streams.errors;
\ No newline at end of file
diff --git a/streams/src/main/java/org/apache/kafka/streams/kstream/package-info.java b/streams/src/main/java/org/apache/kafka/streams/kstream/package-info.java
new file mode 100644
index 00000000000..36f6717fc0b
--- /dev/null
+++ b/streams/src/main/java/org/apache/kafka/streams/kstream/package-info.java
@@ -0,0 +1,21 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Provides a high-level programming model (DSL) to express a (stateful) data flow computation over input {@link org.apache.kafka.streams.kstream.KStream streams} and {@link org.apache.kafka.streams.kstream.KTable tables}.
+ * Use {@link org.apache.kafka.streams.StreamsBuilder} as entry for your program.
+ */
+package org.apache.kafka.streams.kstream;
\ No newline at end of file
diff --git a/streams/src/main/java/org/apache/kafka/streams/package-info.java b/streams/src/main/java/org/apache/kafka/streams/package-info.java
new file mode 100644
index 00000000000..1f7be384fa2
--- /dev/null
+++ b/streams/src/main/java/org/apache/kafka/streams/package-info.java
@@ -0,0 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Provides the Kafka Streams library for building streaming data applications.
+ */
+package org.apache.kafka.streams;
\ No newline at end of file
diff --git a/streams/src/main/java/org/apache/kafka/streams/processor/api/package-info.java b/streams/src/main/java/org/apache/kafka/streams/processor/api/package-info.java
new file mode 100644
index 00000000000..b5e3e604bff
--- /dev/null
+++ b/streams/src/main/java/org/apache/kafka/streams/processor/api/package-info.java
@@ -0,0 +1,21 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Provides a low-level programming model (Processor API, aka, PAPI) to express a (stateful) data flow computation over input topics.
+ * Use {@link org.apache.kafka.streams.Topology} as the entry point for your program.
+ */
+package org.apache.kafka.streams.processor.api;
\ No newline at end of file
diff --git a/streams/src/main/java/org/apache/kafka/streams/processor/package-info.java b/streams/src/main/java/org/apache/kafka/streams/processor/package-info.java
new file mode 100644
index 00000000000..31b4894b89c
--- /dev/null
+++ b/streams/src/main/java/org/apache/kafka/streams/processor/package-info.java
@@ -0,0 +1,21 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Provides a low-level programming model (Processor API, aka, PAPI) to express a (stateful) data flow computation over input topics.
+ * Use {@link org.apache.kafka.streams.Topology} as the entry point for your program.
+ */
+package org.apache.kafka.streams.processor;
\ No newline at end of file
diff --git a/streams/src/main/java/org/apache/kafka/streams/query/package-info.java b/streams/src/main/java/org/apache/kafka/streams/query/package-info.java
new file mode 100644
index 00000000000..a2f15f4a0cb
--- /dev/null
+++ b/streams/src/main/java/org/apache/kafka/streams/query/package-info.java
@@ -0,0 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Provides a query API (aka Interactive Queries) over state stores, for extracting data from a stateful Kafka Streams application.
+ */
+package org.apache.kafka.streams.query;
\ No newline at end of file
diff --git a/streams/src/main/java/org/apache/kafka/streams/state/package-info.java b/streams/src/main/java/org/apache/kafka/streams/state/package-info.java
new file mode 100644
index 00000000000..92a1878dd0b
--- /dev/null
+++ b/streams/src/main/java/org/apache/kafka/streams/state/package-info.java
@@ -0,0 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Provides interfaces for managing the intermediate state of a stateful streams application.
+ */
+package org.apache.kafka.streams.state;
\ No newline at end of file
diff --git a/streams/test-utils/src/main/java/org/apache/kafka/streams/test/package-info.java b/streams/test-utils/src/main/java/org/apache/kafka/streams/test/package-info.java
new file mode 100644
index 00000000000..129d513f3b6
--- /dev/null
+++ b/streams/test-utils/src/main/java/org/apache/kafka/streams/test/package-info.java
@@ -0,0 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * Provides classes for testing Kafka Streams applications with mocked inputs.
+ */
+package org.apache.kafka.streams.test;
\ No newline at end of file