You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by sj...@apache.org on 2021/05/27 14:27:50 UTC

[flink] branch master updated: [FLINK-22746][docs] Links to connectors in docs are broken

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

sjwiesman pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git


The following commit(s) were added to refs/heads/master by this push:
     new 8340212  [FLINK-22746][docs] Links to connectors in docs are broken
8340212 is described below

commit 83402127c1e1ba264096f1e70fbbdbe005a0e8b4
Author: Authuir <au...@authuir.com>
AuthorDate: Sun May 23 02:21:41 2021 +0800

    [FLINK-22746][docs] Links to connectors in docs are broken
    
    This closes #15990
---
 .../docs/connectors/datastream/overview.md         | 22 +++++++++++-----------
 .../content/docs/connectors/datastream/overview.md | 22 +++++++++++-----------
 2 files changed, 22 insertions(+), 22 deletions(-)

diff --git a/docs/content.zh/docs/connectors/datastream/overview.md b/docs/content.zh/docs/connectors/datastream/overview.md
index cc59b1d..889f38f 100644
--- a/docs/content.zh/docs/connectors/datastream/overview.md
+++ b/docs/content.zh/docs/connectors/datastream/overview.md
@@ -37,17 +37,17 @@ under the License.
 
 连接器可以和多种多样的第三方系统进行交互。目前支持以下系统:
 
- * [Apache Kafka](kafka.html) (source/sink)
- * [Apache Cassandra](cassandra.html) (sink)
- * [Amazon Kinesis Streams](kinesis.html) (source/sink)
- * [Elasticsearch](elasticsearch.html) (sink)
- * [FileSystem(包括 Hadoop ) - 仅支持流](streamfile_sink.html) (sink)
- * [FileSystem(包括 Hadoop ) - 流批统一](file_sink.html) (sink)
- * [RabbitMQ](rabbitmq.html) (source/sink)
- * [Apache NiFi](nifi.html) (source/sink)
- * [Twitter Streaming API](twitter.html) (source)
- * [Google PubSub](pubsub.html) (source/sink)
- * [JDBC](jdbc.html) (sink)
+ * [Apache Kafka]({{< ref "docs/connectors/datastream/kafka" >}}) (source/sink)
+ * [Apache Cassandra]({{< ref "docs/connectors/datastream/cassandra" >}}) (sink)
+ * [Amazon Kinesis Streams]({{< ref "docs/connectors/datastream/kinesis" >}}) (source/sink)
+ * [Elasticsearch]({{< ref "docs/connectors/datastream/elasticsearch" >}}) (sink)
+ * [FileSystem(包括 Hadoop ) - 仅支持流]({{< ref "docs/connectors/datastream/streamfile_sink" >}}) (sink)
+ * [FileSystem(包括 Hadoop ) - 流批统一]({{< ref "docs/connectors/datastream/file_sink" >}}) (sink)
+ * [RabbitMQ]({{< ref "docs/connectors/datastream/rabbitmq" >}}) (source/sink)
+ * [Apache NiFi]({{< ref "docs/connectors/datastream/nifi" >}}) (source/sink)
+ * [Twitter Streaming API]({{< ref "docs/connectors/datastream/twitter" >}}) (source)
+ * [Google PubSub]({{< ref "docs/connectors/datastream/pubsub" >}}) (source/sink)
+ * [JDBC]({{< ref "docs/connectors/datastream/jdbc" >}}) (sink)
 
 请记住,在使用一种连接器时,通常需要额外的第三方组件,比如:数据存储服务器或者消息队列。
 要注意这些列举的连接器是 Flink 工程的一部分,包含在发布的源码中,但是不包含在二进制发行版中。
diff --git a/docs/content/docs/connectors/datastream/overview.md b/docs/content/docs/connectors/datastream/overview.md
index f279b0e..b6b6f24 100644
--- a/docs/content/docs/connectors/datastream/overview.md
+++ b/docs/content/docs/connectors/datastream/overview.md
@@ -38,17 +38,17 @@ The [predefined data sinks]({{< ref "docs/dev/datastream/overview" >}}#data-sink
 
 Connectors provide code for interfacing with various third-party systems. Currently these systems are supported:
 
- * [Apache Kafka](kafka.html) (source/sink)
- * [Apache Cassandra](cassandra.html) (sink)
- * [Amazon Kinesis Streams](kinesis.html) (source/sink)
- * [Elasticsearch](elasticsearch.html) (sink)
- * [FileSystem (Hadoop included) - Streaming only](streamfile_sink.html) (sink)
- * [FileSystem (Hadoop included) - Streaming and Batch](file_sink.html) (sink)
- * [RabbitMQ](rabbitmq.html) (source/sink)
- * [Apache NiFi](nifi.html) (source/sink)
- * [Twitter Streaming API](twitter.html) (source)
- * [Google PubSub](pubsub.html) (source/sink)
- * [JDBC](jdbc.html) (sink)
+ * [Apache Kafka]({{< ref "docs/connectors/datastream/kafka" >}}) (source/sink)
+ * [Apache Cassandra]({{< ref "docs/connectors/datastream/cassandra" >}}) (sink)
+ * [Amazon Kinesis Streams]({{< ref "docs/connectors/datastream/kinesis" >}}) (source/sink)
+ * [Elasticsearch]({{< ref "docs/connectors/datastream/elasticsearch" >}}) (sink)
+ * [FileSystem (Hadoop included) - Streaming only]({{< ref "docs/connectors/datastream/streamfile_sink" >}}) (sink)
+ * [FileSystem (Hadoop included) - Streaming and Batch]({{< ref "docs/connectors/datastream/file_sink" >}}) (sink)
+ * [RabbitMQ]({{< ref "docs/connectors/datastream/rabbitmq" >}}) (source/sink)
+ * [Apache NiFi]({{< ref "docs/connectors/datastream/nifi" >}}) (source/sink)
+ * [Twitter Streaming API]({{< ref "docs/connectors/datastream/twitter" >}}) (source)
+ * [Google PubSub]({{< ref "docs/connectors/datastream/pubsub" >}}) (source/sink)
+ * [JDBC]({{< ref "docs/connectors/datastream/jdbc" >}}) (sink)
 
 Keep in mind that to use one of these connectors in an application, additional third party
 components are usually required, e.g. servers for the data stores or message queues.