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/11/22 17:00:53 UTC

[GitHub] [flink] pnowojski opened a new pull request, #21366: [FLINK-30155][streaming] Pretty print MutatedConfigurationException

pnowojski opened a new pull request, #21366:
URL: https://github.com/apache/flink/pull/21366

   The new message will look like:
   
   org.apache.flink.client.program.MutatedConfigurationException: Not allowed configuration change(s) were detected:
    - Configuration execution.sorted-inputs.enabled:true not allowed.
    - Configuration execution.runtime-mode was changed from STREAMING to BATCH.
    - Configuration execution.checkpointing.interval:500 ms not allowed in the configuration object CheckpointConfig.
    - Configuration execution.checkpointing.mode:EXACTLY_ONCE not allowed in the configuration object CheckpointConfig.
    - Configuration pipeline.max-parallelism:1024 not allowed in the configuration object ExecutionConfig.
    - Configuration parallelism.default:25 not allowed in the configuration object ExecutionConfig.
   
   	at org.apache.flink.client.program.StreamContextEnvironment.checkNotAllowedConfigurations(StreamContextEnvironment.java:235)
   	at org.apache.flink.client.program.StreamContextEnvironment.executeAsync(StreamContextEnvironment.java:175)
   	at org.apache.flink.client.program.StreamContextEnvironment.execute(StreamContextEnvironment.java:115)
   	at org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:2049)
   	at org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:2027)
   
   Instead of:
   
   org.apache.flink.client.program.MutatedConfigurationException: Configuration execution.sorted-inputs.enabled:true not allowed. Configuration execution.runtime-mode was changed from STREAMING to BATCH. Configuration execution.checkpointing.interval:500 ms not allowed in the configuration object CheckpointConfig. Configuration execution.checkpointing.mode:EXACTLY_ONCE not allowed in the configuration object CheckpointConfig. Configuration pipeline.max-parallelism:1024 not allowed in the configuration object ExecutionConfig. Configuration parallelism.default:25 not allowed in the configuration object ExecutionConfig.
   
   	at org.apache.flink.client.program.StreamContextEnvironment.checkNotAllowedConfigurations(StreamContextEnvironment.java:235)
   	at org.apache.flink.client.program.StreamContextEnvironment.executeAsync(StreamContextEnvironment.java:175)
   	at org.apache.flink.client.program.StreamContextEnvironment.execute(StreamContextEnvironment.java:115)
   	at org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:2049)
   	at org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:2027)
   
   ## Does this pull request potentially affect one of the following parts:
   
     - Dependencies (does it add or upgrade a dependency): (yes / **no**)
     - The public API, i.e., is any changed class annotated with `@Public(Evolving)`: (yes / **no**)
     - The serializers: (yes / **no** / don't know)
     - The runtime per-record code paths (performance sensitive): (yes / **no** / don't know)
     - Anything that affects deployment or recovery: JobManager (and its components), Checkpointing, Kubernetes/Yarn, ZooKeeper: (yes / **no** / don't know)
     - The S3 file system connector: (yes / **no** / don't know)
   
   ## Documentation
   
     - Does this pull request introduce a new feature? (yes / **no**)
     - If yes, how is the feature documented? (**not applicable** / docs / JavaDocs / not documented)
   


-- 
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] flinkbot commented on pull request #21366: [FLINK-30155][streaming] Pretty print MutatedConfigurationException

Posted by GitBox <gi...@apache.org>.
flinkbot commented on PR #21366:
URL: https://github.com/apache/flink/pull/21366#issuecomment-1323993083

   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "6d29e95a6af0f8848858df622efcc885f98650ad",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "6d29e95a6af0f8848858df622efcc885f98650ad",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 6d29e95a6af0f8848858df622efcc885f98650ad UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run azure` re-run the last Azure build
   </details>


-- 
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] pnowojski merged pull request #21366: [FLINK-30155][streaming] Pretty print MutatedConfigurationException

Posted by GitBox <gi...@apache.org>.
pnowojski merged PR #21366:
URL: https://github.com/apache/flink/pull/21366


-- 
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