You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by se...@apache.org on 2020/05/14 13:31:15 UTC

[flink] branch master updated (3bb18bb -> b3cdd23)

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

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


    from 3bb18bb  [FLINK-17665][network] Replace isBuffer with BufferType field in BufferResponse
     new e0438f9  [hotfix][test] Disable Google PubSub Emulator e2e test on aarch64
     new f05faee  [hotfix][runtime] Remove useless class ZooKeeperCompletedCheckpointStoreITCase
     new b3cdd23  [hotfix][typo]Fix typo in task_lifecycle docs

The 3 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 docs/internals/task_lifecycle.md                          |  2 +-
 docs/internals/task_lifecycle.zh.md                       |  2 +-
 flink-end-to-end-tests/run-nightly-tests.sh               | 15 ++++++++-------
 .../ZooKeeperCompletedCheckpointStoreITCase.java          |  9 ---------
 4 files changed, 10 insertions(+), 18 deletions(-)


[flink] 01/03: [hotfix][test] Disable Google PubSub Emulator e2e test on aarch64

Posted by se...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit e0438f9d47d96b4aa5f681061a7fcf37f2a65c2a
Author: wangxiyuan <wa...@gmail.com>
AuthorDate: Wed May 13 10:00:50 2020 +0800

    [hotfix][test] Disable Google PubSub Emulator e2e test on aarch64
    
    This closes #12111
---
 flink-end-to-end-tests/run-nightly-tests.sh | 15 ++++++++-------
 1 file changed, 8 insertions(+), 7 deletions(-)

diff --git a/flink-end-to-end-tests/run-nightly-tests.sh b/flink-end-to-end-tests/run-nightly-tests.sh
index 7cd6f0b..c68b678 100755
--- a/flink-end-to-end-tests/run-nightly-tests.sh
+++ b/flink-end-to-end-tests/run-nightly-tests.sh
@@ -133,14 +133,15 @@ if [[ ${PROFILE} != *"jdk11"* ]]; then
 	if [[ `uname -i` != 'aarch64' ]]; then
 		# Hadoop YARN deosn't support aarch64 at this moment. See: https://issues.apache.org/jira/browse/HADOOP-16723
 		run_test "Running Kerberized YARN per-job on Docker test (default input)" "$END_TO_END_DIR/test-scripts/test_yarn_job_kerberos_docker.sh"
-    run_test "Running Kerberized YARN per-job on Docker test (custom fs plugin)" "$END_TO_END_DIR/test-scripts/test_yarn_job_kerberos_docker.sh dummy-fs"
-    run_test "Running Kerberized YARN application on Docker test (default input)" "$END_TO_END_DIR/test-scripts/test_yarn_application_kerberos_docker.sh"
-    run_test "Running Kerberized YARN application on Docker test (custom fs plugin)" "$END_TO_END_DIR/test-scripts/test_yarn_application_kerberos_docker.sh dummy-fs"
-	run_test "Run Mesos WordCount test" "$END_TO_END_DIR/test-scripts/test_mesos_wordcount.sh"
-	run_test "Run Mesos multiple submission test" "$END_TO_END_DIR/test-scripts/test_mesos_multiple_submissions.sh"
+		run_test "Running Kerberized YARN per-job on Docker test (custom fs plugin)" "$END_TO_END_DIR/test-scripts/test_yarn_job_kerberos_docker.sh dummy-fs"
+		run_test "Running Kerberized YARN application on Docker test (default input)" "$END_TO_END_DIR/test-scripts/test_yarn_application_kerberos_docker.sh"
+		run_test "Running Kerberized YARN application on Docker test (custom fs plugin)" "$END_TO_END_DIR/test-scripts/test_yarn_application_kerberos_docker.sh dummy-fs"
+		run_test "Run Mesos WordCount test" "$END_TO_END_DIR/test-scripts/test_mesos_wordcount.sh"
+		run_test "Run Mesos multiple submission test" "$END_TO_END_DIR/test-scripts/test_mesos_multiple_submissions.sh"
+
+		# `google/cloud-sdk` docker image doesn't support aarch64 currently.
+		run_test "Test PubSub connector with Docker based Google PubSub Emulator" "$END_TO_END_DIR/test-scripts/test_streaming_gcp_pubsub.sh"
 	fi
-
-	run_test "Test PubSub connector with Docker based Google PubSub Emulator" "$END_TO_END_DIR/test-scripts/test_streaming_gcp_pubsub.sh"
 fi
 
 ################################################################################


[flink] 02/03: [hotfix][runtime] Remove useless class ZooKeeperCompletedCheckpointStoreITCase

Posted by se...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit f05faeefde743212910c5cbbb3ad5e7bb88a5792
Author: felixzheng <fe...@gmail.com>
AuthorDate: Mon May 11 19:55:39 2020 +0800

    [hotfix][runtime] Remove useless class ZooKeeperCompletedCheckpointStoreITCase
    
    This closes #12083
---
 .../checkpoint/ZooKeeperCompletedCheckpointStoreITCase.java      | 9 ---------
 1 file changed, 9 deletions(-)

diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/checkpoint/ZooKeeperCompletedCheckpointStoreITCase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/checkpoint/ZooKeeperCompletedCheckpointStoreITCase.java
index 859f1b9..725d4df 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/checkpoint/ZooKeeperCompletedCheckpointStoreITCase.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/checkpoint/ZooKeeperCompletedCheckpointStoreITCase.java
@@ -23,7 +23,6 @@ import org.apache.flink.runtime.concurrent.Executors;
 import org.apache.flink.runtime.state.RetrievableStateHandle;
 import org.apache.flink.runtime.state.SharedStateRegistry;
 import org.apache.flink.runtime.util.ZooKeeperUtils;
-import org.apache.flink.runtime.zookeeper.RetrievableStateStorageHelper;
 import org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore;
 import org.apache.flink.runtime.zookeeper.ZooKeeperTestEnvironment;
 
@@ -284,14 +283,6 @@ public class ZooKeeperCompletedCheckpointStoreITCase extends CompletedCheckpoint
 		recoveredTestCheckpoint.awaitDiscard();
 	}
 
-
-	static class HeapStateStorageHelper implements RetrievableStateStorageHelper<CompletedCheckpoint> {
-		@Override
-		public RetrievableStateHandle<CompletedCheckpoint> store(CompletedCheckpoint state) throws Exception {
-			return new HeapRetrievableStateHandle<>(state);
-		}
-	}
-
 	static class HeapRetrievableStateHandle<T extends Serializable> implements RetrievableStateHandle<T> {
 
 		private static final long serialVersionUID = -268548467968932L;


[flink] 03/03: [hotfix][typo]Fix typo in task_lifecycle docs

Posted by se...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit b3cdd23727709f6c5f2393b5463e3449769a2f17
Author: gk0916 <gk...@gmail.com>
AuthorDate: Mon May 11 14:34:33 2020 +0800

    [hotfix][typo]Fix typo in task_lifecycle docs
    
    This closes #12068
---
 docs/internals/task_lifecycle.md    | 2 +-
 docs/internals/task_lifecycle.zh.md | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)

diff --git a/docs/internals/task_lifecycle.md b/docs/internals/task_lifecycle.md
index 182c99c..44f847f 100644
--- a/docs/internals/task_lifecycle.md
+++ b/docs/internals/task_lifecycle.md
@@ -23,7 +23,7 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-A task in Flink is the basic unit of execution. It is the place where each parallel instance of an operator is executed
+A task in Flink is the basic unit of execution. It is the place where each parallel instance of an operator is executed.
 As an example, an operator with a parallelism of *5* will have each of its instances executed by a separate task. 
 
 The `StreamTask` is the base for all different task sub-types in Flink's streaming engine. This document goes through 
diff --git a/docs/internals/task_lifecycle.zh.md b/docs/internals/task_lifecycle.zh.md
index e3301fe..7de935b 100644
--- a/docs/internals/task_lifecycle.zh.md
+++ b/docs/internals/task_lifecycle.zh.md
@@ -23,7 +23,7 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-A task in Flink is the basic unit of execution. It is the place where each parallel instance of an operator is executed
+A task in Flink is the basic unit of execution. It is the place where each parallel instance of an operator is executed.
 As an example, an operator with a parallelism of *5* will have each of its instances executed by a separate task. 
 
 The `StreamTask` is the base for all different task sub-types in Flink's streaming engine. This document goes through