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 2019/07/24 07:41:33 UTC

[GitHub] [flink] twalthr commented on a change in pull request #9203: [FLINK-13375][table-api] Improve config names in ExecutionConfigOptions and OptimizerConfigOptions

twalthr commented on a change in pull request #9203: [FLINK-13375][table-api] Improve config names in ExecutionConfigOptions and OptimizerConfigOptions
URL: https://github.com/apache/flink/pull/9203#discussion_r306668437
 
 

 ##########
 File path: flink-table/flink-table-api-java/src/main/java/org/apache/flink/table/api/config/ExecutionConfigOptions.java
 ##########
 @@ -83,97 +83,97 @@
 	//  Resource Options
 	// ------------------------------------------------------------------------
 
-	public static final ConfigOption<Integer> SQL_RESOURCE_DEFAULT_PARALLELISM =
-			key("sql.resource.default.parallelism")
+	public static final ConfigOption<Integer> TABLE_EXEC_RESOURCE_DEFAULT_PARALLELISM =
+			key("table.exec.resource.default-parallelism")
 					.defaultValue(-1)
 					.withDescription("Default parallelism of job operators. If it is <= 0, use parallelism of StreamExecutionEnvironment(" +
 							"its default value is the num of cpu cores in the client host).");
 
-	public static final ConfigOption<Integer> SQL_RESOURCE_SOURCE_PARALLELISM =
-			key("sql.resource.source.parallelism")
+	public static final ConfigOption<Integer> TABLE_EXEC_RESOURCE_SOURCE_PARALLELISM =
+			key("table.exec.resource.source.parallelism")
 					.defaultValue(-1)
-					.withDescription("Sets source parallelism, if it is <= 0, use " + SQL_RESOURCE_DEFAULT_PARALLELISM.key() + " to set source parallelism.");
+					.withDescription("Sets source parallelism, if it is <= 0, use " + TABLE_EXEC_RESOURCE_DEFAULT_PARALLELISM.key() + " to set source parallelism.");
 
-	public static final ConfigOption<Integer> SQL_RESOURCE_SINK_PARALLELISM =
-			key("sql.resource.sink.parallelism")
+	public static final ConfigOption<Integer> TABLE_EXEC_RESOURCE_SINK_PARALLELISM =
+			key("table.exec.resource.sink.parallelism")
 					.defaultValue(-1)
-					.withDescription("Sets sink parallelism, if it is <= 0, use " + SQL_RESOURCE_DEFAULT_PARALLELISM.key() + " to set sink parallelism.");
+					.withDescription("Sets sink parallelism, if it is <= 0, use " + TABLE_EXEC_RESOURCE_DEFAULT_PARALLELISM.key() + " to set sink parallelism.");
 
-	public static final ConfigOption<Integer> SQL_RESOURCE_EXTERNAL_BUFFER_MEM =
-			key("sql.resource.external-buffer.memory.mb")
-					.defaultValue(10)
+	public static final ConfigOption<String> TABLE_EXEC_RESOURCE_EXTERNAL_BUFFER_MEM =
+			key("table.exec.resource.external-buffer.memory")
+					.defaultValue("10 mb")
 					.withDescription("Sets the externalBuffer memory size that is used in sortMergeJoin and overWindow.");
 
-	public static final ConfigOption<Integer> SQL_RESOURCE_HASH_AGG_TABLE_MEM =
-			key("sql.resource.hash-agg.table.memory.mb")
-					.defaultValue(128)
-					.withDescription("Sets the table memory size of hashAgg operator.");
+	public static final ConfigOption<String> TABLE_EXEC_RESOURCE_HASH_AGG_TABLE_MEM =
+			key("table.exec.resource.hash-agg.memory")
+					.defaultValue("128 mb")
+					.withDescription("Sets the managed memory size of hash aggregate operator.");
 
-	public static final ConfigOption<Integer> SQL_RESOURCE_HASH_JOIN_TABLE_MEM =
-			key("sql.resource.hash-join.table.memory.mb")
-					.defaultValue(128)
-					.withDescription("Sets the HashTable reserved memory for hashJoin operator. It defines the lower limit.");
+	public static final ConfigOption<String> TABLE_EXEC_RESOURCE_HASH_JOIN_TABLE_MEM =
+			key("table.exec.resource.hash-join.memory")
+					.defaultValue("128 mb")
+					.withDescription("Sets the managed memory for hash join operator. It defines the lower limit.");
 
-	public static final ConfigOption<Integer> SQL_RESOURCE_SORT_BUFFER_MEM =
-			key("sql.resource.sort.buffer.memory.mb")
-					.defaultValue(128)
+	public static final ConfigOption<String> TABLE_EXEC_RESOURCE_SORT_BUFFER_MEM =
+			key("table.exec.resource.sort.buffer.memory")
+					.defaultValue("128 mb")
 					.withDescription("Sets the buffer memory size for sort.");
 
 	// ------------------------------------------------------------------------
 	//  Agg Options
 	// ------------------------------------------------------------------------
 
-	public static final ConfigOption<Integer> SQL_EXEC_WINDOW_AGG_BUFFER_SIZE_LIMIT =
-			key("sql.exec.window-agg.buffer-size-limit")
+	public static final ConfigOption<Integer> TABLE_EXEC_WINDOW_AGG_BUFFER_SIZE_LIMIT =
+			key("table.exec.window-agg.buffer-size-limit")
 					.defaultValue(100 * 1000)
 					.withDescription("Sets the window elements buffer size limit used in group window agg operator.");
 
 	// ------------------------------------------------------------------------
 	//  Async Lookup Options
 	// ------------------------------------------------------------------------
-	public static final ConfigOption<Integer> SQL_EXEC_LOOKUP_ASYNC_BUFFER_CAPACITY =
-			key("sql.exec.lookup.async.buffer-capacity")
+	public static final ConfigOption<Integer> TABLE_EXEC_LOOKUP_ASYNC_BUFFER_CAPACITY =
+			key("table.exec.lookup.async.buffer-capacity")
 
 Review comment:
   Sounds good.

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services