You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by GitBox <gi...@apache.org> on 2022/07/06 12:54:44 UTC

[GitHub] [flink-connector-elasticsearch] deadwind4 opened a new pull request, #23: [FLINK-28428][connectors/elasticsearch][docs][docs-zh] Fix example and Chinese translations

deadwind4 opened a new pull request, #23:
URL: https://github.com/apache/flink-connector-elasticsearch/pull/23

   The example in the Elasticsearch doc of the fault tolerance section is missing.
   Chinese translations of the fault tolerance section are missing.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [flink-connector-elasticsearch] deadwind4 commented on a diff in pull request #23: [FLINK-28428][connectors/elasticsearch][docs][docs-zh] Fix example and Chinese translations

Posted by GitBox <gi...@apache.org>.
deadwind4 commented on code in PR #23:
URL: https://github.com/apache/flink-connector-elasticsearch/pull/23#discussion_r914913295


##########
docs/content/docs/connectors/datastream/elasticsearch.md:
##########
@@ -226,17 +226,60 @@ To use fault tolerant Elasticsearch Sinks, checkpointing of the topology needs t
 
 {{< tabs "d00d1e93-4844-40d7-b0ec-9ec37e73145e" >}}
 {{< tab "Java" >}}
+
+Elasticsearch 6:
+```java
+final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
+env.enableCheckpointing(5000); // checkpoint every 5000 msecs
+
+Elasticsearch6SinkBuilder sinkBuilder = new Elasticsearch6SinkBuilder<String>()
+    .setDeliveryGuarantee(DeliveryGuarantee.AT_LEAST_ONCE)
+    .setHosts(new HttpHost("127.0.0.1", 9200, "http"))
+    .setEmitter(
+    (element, context, indexer) -> 
+    indexer.add(createIndexRequest(element)));

Review Comment:
   Whether this commit changes an error doc file? Should we change the English doc but change the Chinese doc? https://github.com/apache/flink-connector-elasticsearch/commit/3c9430593d9d61254b63a66234d8dba9c269060b



##########
docs/content/docs/connectors/datastream/elasticsearch.md:
##########
@@ -226,17 +226,60 @@ To use fault tolerant Elasticsearch Sinks, checkpointing of the topology needs t
 
 {{< tabs "d00d1e93-4844-40d7-b0ec-9ec37e73145e" >}}
 {{< tab "Java" >}}
+
+Elasticsearch 6:
+```java
+final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
+env.enableCheckpointing(5000); // checkpoint every 5000 msecs
+
+Elasticsearch6SinkBuilder sinkBuilder = new Elasticsearch6SinkBuilder<String>()
+    .setDeliveryGuarantee(DeliveryGuarantee.AT_LEAST_ONCE)
+    .setHosts(new HttpHost("127.0.0.1", 9200, "http"))
+    .setEmitter(
+    (element, context, indexer) -> 
+    indexer.add(createIndexRequest(element)));

Review Comment:
   Whether this commit https://github.com/apache/flink-connector-elasticsearch/commit/3c9430593d9d61254b63a66234d8dba9c269060b changes an error doc file? Should we change the English doc but change the Chinese doc? 



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [flink-connector-elasticsearch] MartijnVisser commented on a diff in pull request #23: [FLINK-28428][connectors/elasticsearch][docs][docs-zh] Fix example and Chinese translations

Posted by GitBox <gi...@apache.org>.
MartijnVisser commented on code in PR #23:
URL: https://github.com/apache/flink-connector-elasticsearch/pull/23#discussion_r1036889587


##########
docs/content/docs/connectors/datastream/elasticsearch.md:
##########
@@ -226,17 +226,60 @@ To use fault tolerant Elasticsearch Sinks, checkpointing of the topology needs t
 
 {{< tabs "d00d1e93-4844-40d7-b0ec-9ec37e73145e" >}}
 {{< tab "Java" >}}
+
+Elasticsearch 6:
+```java
+final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
+env.enableCheckpointing(5000); // checkpoint every 5000 msecs
+
+Elasticsearch6SinkBuilder sinkBuilder = new Elasticsearch6SinkBuilder<String>()
+    .setDeliveryGuarantee(DeliveryGuarantee.AT_LEAST_ONCE)
+    .setHosts(new HttpHost("127.0.0.1", 9200, "http"))
+    .setEmitter(
+    (element, context, indexer) -> 
+    indexer.add(createIndexRequest(element)));

Review Comment:
   The documentation at https://nightlies.apache.org/flink/flink-docs-master/api/java/org/apache/flink/connector/elasticsearch/sink/Elasticsearch6SinkBuilder.html is correct from what I've understood



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [flink-connector-elasticsearch] MartijnVisser commented on a diff in pull request #23: [FLINK-28428][connectors/elasticsearch][docs][docs-zh] Fix example and Chinese translations

Posted by GitBox <gi...@apache.org>.
MartijnVisser commented on code in PR #23:
URL: https://github.com/apache/flink-connector-elasticsearch/pull/23#discussion_r914906340


##########
docs/content/docs/connectors/datastream/elasticsearch.md:
##########
@@ -226,17 +226,60 @@ To use fault tolerant Elasticsearch Sinks, checkpointing of the topology needs t
 
 {{< tabs "d00d1e93-4844-40d7-b0ec-9ec37e73145e" >}}
 {{< tab "Java" >}}
+
+Elasticsearch 6:
+```java
+final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
+env.enableCheckpointing(5000); // checkpoint every 5000 msecs
+
+Elasticsearch6SinkBuilder sinkBuilder = new Elasticsearch6SinkBuilder<String>()
+    .setDeliveryGuarantee(DeliveryGuarantee.AT_LEAST_ONCE)
+    .setHosts(new HttpHost("127.0.0.1", 9200, "http"))
+    .setEmitter(
+    (element, context, indexer) -> 
+    indexer.add(createIndexRequest(element)));

Review Comment:
   This doesn't match with the JavaDoc. I'm not sure that the Chinese documentation is correct, based on FLINK-25589 and FLINK-26634. 



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [flink-connector-elasticsearch] deadwind4 commented on a diff in pull request #23: [FLINK-28428][connectors/elasticsearch][docs][docs-zh] Fix example and Chinese translations

Posted by GitBox <gi...@apache.org>.
deadwind4 commented on code in PR #23:
URL: https://github.com/apache/flink-connector-elasticsearch/pull/23#discussion_r914925778


##########
docs/content/docs/connectors/datastream/elasticsearch.md:
##########
@@ -226,17 +226,60 @@ To use fault tolerant Elasticsearch Sinks, checkpointing of the topology needs t
 
 {{< tabs "d00d1e93-4844-40d7-b0ec-9ec37e73145e" >}}
 {{< tab "Java" >}}
+
+Elasticsearch 6:
+```java
+final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
+env.enableCheckpointing(5000); // checkpoint every 5000 msecs
+
+Elasticsearch6SinkBuilder sinkBuilder = new Elasticsearch6SinkBuilder<String>()
+    .setDeliveryGuarantee(DeliveryGuarantee.AT_LEAST_ONCE)
+    .setHosts(new HttpHost("127.0.0.1", 9200, "http"))
+    .setEmitter(
+    (element, context, indexer) -> 
+    indexer.add(createIndexRequest(element)));

Review Comment:
   I found the Chinese translations of `IMPORTANT: Checkpointing is not enabled by default but  ....... ` was deleted and the example of the fault tolerance section in the English doc wasn't updated in this former commit.



##########
docs/content/docs/connectors/datastream/elasticsearch.md:
##########
@@ -226,17 +226,60 @@ To use fault tolerant Elasticsearch Sinks, checkpointing of the topology needs t
 
 {{< tabs "d00d1e93-4844-40d7-b0ec-9ec37e73145e" >}}
 {{< tab "Java" >}}
+
+Elasticsearch 6:
+```java
+final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
+env.enableCheckpointing(5000); // checkpoint every 5000 msecs
+
+Elasticsearch6SinkBuilder sinkBuilder = new Elasticsearch6SinkBuilder<String>()
+    .setDeliveryGuarantee(DeliveryGuarantee.AT_LEAST_ONCE)
+    .setHosts(new HttpHost("127.0.0.1", 9200, "http"))
+    .setEmitter(
+    (element, context, indexer) -> 
+    indexer.add(createIndexRequest(element)));

Review Comment:
   I found the Chinese translations of `IMPORTANT: Checkpointing is not enabled by default but  .......` was deleted and the example of the fault tolerance section in the English doc wasn't updated in this former commit.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [flink-connector-elasticsearch] deadwind4 commented on a diff in pull request #23: [FLINK-28428][connectors/elasticsearch][docs][docs-zh] Fix example and Chinese translations

Posted by GitBox <gi...@apache.org>.
deadwind4 commented on code in PR #23:
URL: https://github.com/apache/flink-connector-elasticsearch/pull/23#discussion_r914913295


##########
docs/content/docs/connectors/datastream/elasticsearch.md:
##########
@@ -226,17 +226,60 @@ To use fault tolerant Elasticsearch Sinks, checkpointing of the topology needs t
 
 {{< tabs "d00d1e93-4844-40d7-b0ec-9ec37e73145e" >}}
 {{< tab "Java" >}}
+
+Elasticsearch 6:
+```java
+final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
+env.enableCheckpointing(5000); // checkpoint every 5000 msecs
+
+Elasticsearch6SinkBuilder sinkBuilder = new Elasticsearch6SinkBuilder<String>()
+    .setDeliveryGuarantee(DeliveryGuarantee.AT_LEAST_ONCE)
+    .setHosts(new HttpHost("127.0.0.1", 9200, "http"))
+    .setEmitter(
+    (element, context, indexer) -> 
+    indexer.add(createIndexRequest(element)));

Review Comment:
   Whether this commit https://github.com/apache/flink-connector-elasticsearch/commit/3c9430593d9d61254b63a66234d8dba9c269060b changes an error doc file? Should we change the English doc but change the Chinese doc?  @alpreu The only one doc is correct, either Chinese or English.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [flink-connector-elasticsearch] deadwind4 commented on a diff in pull request #23: [FLINK-28428][connectors/elasticsearch][docs][docs-zh] Fix example and Chinese translations

Posted by GitBox <gi...@apache.org>.
deadwind4 commented on code in PR #23:
URL: https://github.com/apache/flink-connector-elasticsearch/pull/23#discussion_r914913295


##########
docs/content/docs/connectors/datastream/elasticsearch.md:
##########
@@ -226,17 +226,60 @@ To use fault tolerant Elasticsearch Sinks, checkpointing of the topology needs t
 
 {{< tabs "d00d1e93-4844-40d7-b0ec-9ec37e73145e" >}}
 {{< tab "Java" >}}
+
+Elasticsearch 6:
+```java
+final StreamExecutionEnvironment env = StreamExecutionEnvironment.getExecutionEnvironment();
+env.enableCheckpointing(5000); // checkpoint every 5000 msecs
+
+Elasticsearch6SinkBuilder sinkBuilder = new Elasticsearch6SinkBuilder<String>()
+    .setDeliveryGuarantee(DeliveryGuarantee.AT_LEAST_ONCE)
+    .setHosts(new HttpHost("127.0.0.1", 9200, "http"))
+    .setEmitter(
+    (element, context, indexer) -> 
+    indexer.add(createIndexRequest(element)));

Review Comment:
   Whether this commit https://github.com/apache/flink-connector-elasticsearch/commit/3c9430593d9d61254b63a66234d8dba9c269060b changes an error doc file? Should we change the English doc but change the Chinese doc?  @alpreu 



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org