You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by ch...@apache.org on 2018/07/04 15:16:27 UTC

[1/3] flink git commit: [FLINK-9729][docs][sql] Remove duplicate row for %W

Repository: flink
Updated Branches:
  refs/heads/master fb37d51f3 -> 59e55cab3


[FLINK-9729][docs][sql] Remove duplicate row for %W

This closes #6246.


Project: http://git-wip-us.apache.org/repos/asf/flink/repo
Commit: http://git-wip-us.apache.org/repos/asf/flink/commit/59e55cab
Tree: http://git-wip-us.apache.org/repos/asf/flink/tree/59e55cab
Diff: http://git-wip-us.apache.org/repos/asf/flink/diff/59e55cab

Branch: refs/heads/master
Commit: 59e55cab3b6e861b6c6a20c93ec4a4ca8c54c265
Parents: 9a5e0c8
Author: snuyanzin <sn...@gmail.com>
Authored: Tue Jul 3 16:53:22 2018 +0300
Committer: zentol <ch...@apache.org>
Committed: Wed Jul 4 17:12:57 2018 +0200

----------------------------------------------------------------------
 docs/dev/table/sql.md | 3 ---
 1 file changed, 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/59e55cab/docs/dev/table/sql.md
----------------------------------------------------------------------
diff --git a/docs/dev/table/sql.md b/docs/dev/table/sql.md
index 7279f40..eb58e75 100644
--- a/docs/dev/table/sql.md
+++ b/docs/dev/table/sql.md
@@ -2748,9 +2748,6 @@ A, ABS, ABSOLUTE, ACTION, ADA, ADD, ADMIN, AFTER, ALL, ALLOCATE, ALLOW, ALTER, A
   <tr><td>{% highlight text %}%W{% endhighlight %}</td>
   <td>Weekday name (<code>Sunday</code> .. <code>Saturday</code>)</td>
   </tr>
-  <tr><td>{% highlight text %}%W{% endhighlight %}</td>
-  <td>Weekday name (<code>Sunday</code> .. <code>Saturday</code>)</td>
-  </tr>
   <tr><td>{% highlight text %}%w{% endhighlight %}</td>
   <td>Day of the week (<code>0</code> .. <code>6</code>), where Sunday is the first day of the week</td>
   </tr>


[2/3] flink git commit: [FLINK-9734][docs][sql] Fix typo

Posted by ch...@apache.org.
[FLINK-9734][docs][sql] Fix typo

This closes #6249.


Project: http://git-wip-us.apache.org/repos/asf/flink/repo
Commit: http://git-wip-us.apache.org/repos/asf/flink/commit/9a5e0c8e
Tree: http://git-wip-us.apache.org/repos/asf/flink/tree/9a5e0c8e
Diff: http://git-wip-us.apache.org/repos/asf/flink/diff/9a5e0c8e

Branch: refs/heads/master
Commit: 9a5e0c8eeef95ce7f12c0fdbd1c6abd991cdc141
Parents: 80be8e1
Author: snuyanzin <sn...@gmail.com>
Authored: Tue Jul 3 20:40:56 2018 +0300
Committer: zentol <ch...@apache.org>
Committed: Wed Jul 4 17:12:57 2018 +0200

----------------------------------------------------------------------
 docs/dev/table/sqlClient.md | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/9a5e0c8e/docs/dev/table/sqlClient.md
----------------------------------------------------------------------
diff --git a/docs/dev/table/sqlClient.md b/docs/dev/table/sqlClient.md
index f850082..4d0c0f0 100644
--- a/docs/dev/table/sqlClient.md
+++ b/docs/dev/table/sqlClient.md
@@ -465,7 +465,7 @@ format:
       type: VARCHAR
     - name: field2
       type: TIMESTAMP
-  field-deleimiter: ","      # optional: string delimiter "," by default 
+  field-delimiter: ","      # optional: string delimiter "," by default 
   line-delimiter: "\n"       # optional: string delimiter "\n" by default 
   quote-character: '"'       # optional: single character for string values, empty by default
   comment-prefix: '#'        # optional: string to indicate comments, empty by default


[3/3] flink git commit: [FLINK-9554][scala-shell] Respect customCommandlines

Posted by ch...@apache.org.
[FLINK-9554][scala-shell] Respect customCommandlines

This closes #6140.


Project: http://git-wip-us.apache.org/repos/asf/flink/repo
Commit: http://git-wip-us.apache.org/repos/asf/flink/commit/80be8e19
Tree: http://git-wip-us.apache.org/repos/asf/flink/tree/80be8e19
Diff: http://git-wip-us.apache.org/repos/asf/flink/diff/80be8e19

Branch: refs/heads/master
Commit: 80be8e19512c19fe4811e7dcfb6da40791fec79b
Parents: fb37d51
Author: Jeff Zhang <zj...@apache.org>
Authored: Thu Jun 7 17:47:32 2018 +0800
Committer: zentol <ch...@apache.org>
Committed: Wed Jul 4 17:12:57 2018 +0200

----------------------------------------------------------------------
 .../org/apache/flink/client/cli/CliFrontend.java    |  4 ++++
 .../org/apache/flink/api/scala/FlinkShell.scala     | 16 +++++++++-------
 2 files changed, 13 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/80be8e19/flink-clients/src/main/java/org/apache/flink/client/cli/CliFrontend.java
----------------------------------------------------------------------
diff --git a/flink-clients/src/main/java/org/apache/flink/client/cli/CliFrontend.java b/flink-clients/src/main/java/org/apache/flink/client/cli/CliFrontend.java
index e9a1590..e2a260c 100644
--- a/flink-clients/src/main/java/org/apache/flink/client/cli/CliFrontend.java
+++ b/flink-clients/src/main/java/org/apache/flink/client/cli/CliFrontend.java
@@ -166,6 +166,10 @@ public class CliFrontend {
 		return copiedConfiguration;
 	}
 
+	public Options getCustomCommandLineOptions() {
+		return customCommandLineOptions;
+	}
+
 	// --------------------------------------------------------------------------------------------
 	//  Execute Actions
 	// --------------------------------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/flink/blob/80be8e19/flink-scala-shell/src/main/scala/org/apache/flink/api/scala/FlinkShell.scala
----------------------------------------------------------------------
diff --git a/flink-scala-shell/src/main/scala/org/apache/flink/api/scala/FlinkShell.scala b/flink-scala-shell/src/main/scala/org/apache/flink/api/scala/FlinkShell.scala
index b74a8a0..ae22d87 100644
--- a/flink-scala-shell/src/main/scala/org/apache/flink/api/scala/FlinkShell.scala
+++ b/flink-scala-shell/src/main/scala/org/apache/flink/api/scala/FlinkShell.scala
@@ -20,6 +20,7 @@ package org.apache.flink.api.scala
 
 import java.io._
 
+import org.apache.commons.cli.{CommandLine, Options}
 import org.apache.flink.client.cli.{CliFrontend, CliFrontendParser}
 import org.apache.flink.client.deployment.ClusterDescriptor
 import org.apache.flink.client.program.ClusterClient
@@ -28,6 +29,7 @@ import org.apache.flink.runtime.akka.AkkaUtils
 import org.apache.flink.runtime.minicluster.{MiniCluster, MiniClusterConfiguration, StandaloneMiniCluster}
 
 import scala.collection.mutable.ArrayBuffer
+import scala.collection.JavaConverters._
 import scala.tools.nsc.Settings
 import scala.tools.nsc.interpreter._
 
@@ -273,14 +275,14 @@ object FlinkShell {
     yarnConfig.queue.foreach((queue) => args ++= Seq("-yqu", queue.toString))
     yarnConfig.slots.foreach((slots) => args ++= Seq("-ys", slots.toString))
 
-    val commandLine = CliFrontendParser.parse(
-      CliFrontendParser.getRunCommandOptions,
-      args.toArray,
-      true)
-
-    val frontend = new CliFrontend(
-      configuration,
+    val frontend = new CliFrontend(configuration,
       CliFrontend.loadCustomCommandLines(configuration, configurationDirectory))
+
+    val commandOptions = CliFrontendParser.getRunCommandOptions
+    val commandLineOptions = CliFrontendParser.mergeOptions(commandOptions,
+      frontend.getCustomCommandLineOptions());
+    val commandLine = CliFrontendParser.parse(commandLineOptions, args.toArray, true)
+
     val customCLI = frontend.getActiveCustomCommandLine(commandLine)
 
     val clusterDescriptor = customCLI.createClusterDescriptor(commandLine)