[ 
https://issues.apache.org/jira/browse/FLINK-10419?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=16686182#comment-16686182
 ] 

ASF GitHub Bot commented on FLINK-10419:
----------------------------------------

dawidwys closed pull request #7089: [FLINK-10419] Using DeclineCheckpoint 
message class when invoking RPC declineCheckpoint 
URL: https://github.com/apache/flink/pull/7089
 
 
   

This is a PR merged from a forked repository.
As GitHub hides the original diff on merge, it is displayed below for
the sake of provenance:

As this is a foreign pull request (from a fork), the diff is supplied
below (as it won't show otherwise due to GitHub magic):

diff --git 
a/flink-runtime/src/main/java/org/apache/flink/runtime/checkpoint/CheckpointCoordinatorGateway.java
 
b/flink-runtime/src/main/java/org/apache/flink/runtime/checkpoint/CheckpointCoordinatorGateway.java
index 22244f6cb8d..b8dc5545706 100644
--- 
a/flink-runtime/src/main/java/org/apache/flink/runtime/checkpoint/CheckpointCoordinatorGateway.java
+++ 
b/flink-runtime/src/main/java/org/apache/flink/runtime/checkpoint/CheckpointCoordinatorGateway.java
@@ -20,6 +20,7 @@
 
 import org.apache.flink.api.common.JobID;
 import org.apache.flink.runtime.executiongraph.ExecutionAttemptID;
+import org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint;
 import org.apache.flink.runtime.rpc.RpcGateway;
 
 public interface CheckpointCoordinatorGateway extends RpcGateway {
@@ -31,9 +32,5 @@ void acknowledgeCheckpoint(
                        final CheckpointMetrics checkpointMetrics,
                        final TaskStateSnapshot subtaskState);
 
-       void declineCheckpoint(
-                       JobID jobID,
-                       ExecutionAttemptID executionAttemptID,
-                       long checkpointId,
-                       Throwable cause);
+       void declineCheckpoint(DeclineCheckpoint declineCheckpoint);
 }
diff --git 
a/flink-runtime/src/main/java/org/apache/flink/runtime/jobmaster/JobMaster.java 
b/flink-runtime/src/main/java/org/apache/flink/runtime/jobmaster/JobMaster.java
index c19346ff8d0..c8a8e882913 100644
--- 
a/flink-runtime/src/main/java/org/apache/flink/runtime/jobmaster/JobMaster.java
+++ 
b/flink-runtime/src/main/java/org/apache/flink/runtime/jobmaster/JobMaster.java
@@ -688,13 +688,7 @@ public void acknowledgeCheckpoint(
 
        // TODO: This method needs a leader session ID
        @Override
-       public void declineCheckpoint(
-                       final JobID jobID,
-                       final ExecutionAttemptID executionAttemptID,
-                       final long checkpointID,
-                       final Throwable reason) {
-               final DeclineCheckpoint decline = new DeclineCheckpoint(
-                               jobID, executionAttemptID, checkpointID, 
reason);
+       public void declineCheckpoint(DeclineCheckpoint decline) {
                final CheckpointCoordinator checkpointCoordinator = 
executionGraph.getCheckpointCoordinator();
 
                if (checkpointCoordinator != null) {
diff --git 
a/flink-runtime/src/main/java/org/apache/flink/runtime/rpc/RpcUtils.java 
b/flink-runtime/src/main/java/org/apache/flink/runtime/rpc/RpcUtils.java
index c90a8b5bbbc..2f656d09263 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/rpc/RpcUtils.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/rpc/RpcUtils.java
@@ -19,9 +19,13 @@
 package org.apache.flink.runtime.rpc;
 
 import org.apache.flink.api.common.time.Time;
+import org.apache.flink.runtime.concurrent.FutureUtils;
 
+import java.util.ArrayList;
+import java.util.Collection;
 import java.util.HashSet;
 import java.util.Set;
+import java.util.concurrent.CompletableFuture;
 import java.util.concurrent.ExecutionException;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.TimeoutException;
@@ -87,6 +91,29 @@ public static void terminateRpcService(RpcService 
rpcService, Time timeout) thro
                rpcService.stopService().get(timeout.toMilliseconds(), 
TimeUnit.MILLISECONDS);
        }
 
+       /**
+        * Shuts the given rpc services down and waits for their termination.
+        *
+        * @param rpcServices to shut down
+        * @param timeout for this operation
+        * @throws InterruptedException if the operation has been interrupted
+        * @throws ExecutionException if a problem occurred
+        * @throws TimeoutException if a timeout occurred
+        */
+       public static void terminateRpcServices(
+                       Time timeout,
+                       RpcService... rpcServices) throws InterruptedException, 
ExecutionException, TimeoutException {
+               final Collection<CompletableFuture<?>> terminationFutures = new 
ArrayList<>(rpcServices.length);
+
+               for (RpcService service : rpcServices) {
+                       if (service != null) {
+                               terminationFutures.add(service.stopService());
+                       }
+               }
+
+               
FutureUtils.waitForAll(terminationFutures).get(timeout.toMilliseconds(), 
TimeUnit.MILLISECONDS);
+       }
+
        // We don't want this class to be instantiable
        private RpcUtils() {}
 }
diff --git 
a/flink-runtime/src/main/java/org/apache/flink/runtime/taskexecutor/rpc/RpcCheckpointResponder.java
 
b/flink-runtime/src/main/java/org/apache/flink/runtime/taskexecutor/rpc/RpcCheckpointResponder.java
index c8f7357ab7e..10c9e2f123a 100644
--- 
a/flink-runtime/src/main/java/org/apache/flink/runtime/taskexecutor/rpc/RpcCheckpointResponder.java
+++ 
b/flink-runtime/src/main/java/org/apache/flink/runtime/taskexecutor/rpc/RpcCheckpointResponder.java
@@ -23,6 +23,7 @@
 import org.apache.flink.runtime.checkpoint.CheckpointMetrics;
 import org.apache.flink.runtime.checkpoint.TaskStateSnapshot;
 import org.apache.flink.runtime.executiongraph.ExecutionAttemptID;
+import org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint;
 import org.apache.flink.runtime.taskmanager.CheckpointResponder;
 import org.apache.flink.util.Preconditions;
 
@@ -57,6 +58,9 @@ public void declineCheckpoint(
                        long checkpointId,
                        Throwable cause) {
 
-               checkpointCoordinatorGateway.declineCheckpoint(jobID, 
executionAttemptID, checkpointId, cause);
+               checkpointCoordinatorGateway.declineCheckpoint(new 
DeclineCheckpoint(jobID,
+                       executionAttemptID,
+                       checkpointId,
+                       cause));
        }
 }
diff --git 
a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTest.java
 
b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTest.java
index 86afa90762e..184f5a6f024 100644
--- 
a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTest.java
+++ 
b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTest.java
@@ -27,6 +27,7 @@
 import org.apache.flink.configuration.Configuration;
 import org.apache.flink.configuration.JobManagerOptions;
 import org.apache.flink.core.testutils.OneShotLatch;
+import org.apache.flink.runtime.akka.AkkaUtils;
 import org.apache.flink.runtime.blob.BlobServer;
 import org.apache.flink.runtime.blob.VoidBlobStore;
 import org.apache.flink.runtime.checkpoint.CheckpointProperties;
@@ -67,12 +68,15 @@
 import org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory;
 import org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService;
 import org.apache.flink.runtime.messages.Acknowledge;
+import org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint;
 import org.apache.flink.runtime.registration.RegistrationResponse;
 import org.apache.flink.runtime.resourcemanager.ResourceManagerId;
 import org.apache.flink.runtime.resourcemanager.SlotRequest;
 import 
org.apache.flink.runtime.resourcemanager.utils.TestingResourceManagerGateway;
+import org.apache.flink.runtime.rpc.RpcService;
 import org.apache.flink.runtime.rpc.RpcUtils;
 import org.apache.flink.runtime.rpc.TestingRpcService;
+import org.apache.flink.runtime.rpc.akka.AkkaRpcService;
 import org.apache.flink.runtime.state.CompletedCheckpointStorageLocation;
 import org.apache.flink.runtime.state.StreamStateHandle;
 import org.apache.flink.runtime.taskexecutor.TestingTaskExecutorGateway;
@@ -83,10 +87,13 @@
 import org.apache.flink.runtime.taskmanager.TaskManagerLocation;
 import org.apache.flink.runtime.testtasks.NoOpInvokable;
 import org.apache.flink.runtime.util.TestingFatalErrorHandler;
+import org.apache.flink.testutils.ClassLoaderUtils;
 import org.apache.flink.util.ExceptionUtils;
 import org.apache.flink.util.FlinkException;
+import org.apache.flink.util.SerializedThrowable;
 import org.apache.flink.util.TestLogger;
 
+import akka.actor.ActorSystem;
 import org.hamcrest.Matchers;
 import org.junit.After;
 import org.junit.AfterClass;
@@ -102,6 +109,7 @@
 import java.io.File;
 import java.io.FileOutputStream;
 import java.io.IOException;
+import java.net.URLClassLoader;
 import java.util.Collection;
 import java.util.Collections;
 import java.util.concurrent.ArrayBlockingQueue;
@@ -211,6 +219,75 @@ public static void teardownClass() {
                }
        }
 
+       @Test
+       public void testDeclineCheckpointInvocationWithUserException() throws 
Exception {
+               RpcService rpcService1 = null;
+               RpcService rpcService2 = null;
+               try {
+                       final ActorSystem actorSystem1 = 
AkkaUtils.createDefaultActorSystem();
+                       final ActorSystem actorSystem2 = 
AkkaUtils.createDefaultActorSystem();
+
+                       rpcService1 = new AkkaRpcService(actorSystem1, 
testingTimeout);
+                       rpcService2 = new AkkaRpcService(actorSystem2, 
testingTimeout);
+
+                       final CompletableFuture<Throwable> 
declineCheckpointMessageFuture = new CompletableFuture<>();
+
+                       final JobManagerSharedServices jobManagerSharedServices 
= new TestingJobManagerSharedServicesBuilder().build();
+                       final JobMasterConfiguration jobMasterConfiguration = 
JobMasterConfiguration.fromConfiguration(configuration);
+                       final JobMaster jobMaster = new JobMaster(
+                               rpcService1,
+                               jobMasterConfiguration,
+                               jmResourceId,
+                               jobGraph,
+                               haServices,
+                               
DefaultSlotPoolFactory.fromConfiguration(configuration, rpcService1),
+                               jobManagerSharedServices,
+                               heartbeatServices,
+                               blobServer,
+                               
UnregisteredJobManagerJobMetricGroupFactory.INSTANCE,
+                               new NoOpOnCompletionActions(),
+                               testingFatalErrorHandler,
+                               JobMasterTest.class.getClassLoader()) {
+                               @Override
+                               public void declineCheckpoint(DeclineCheckpoint 
declineCheckpoint) {
+                                       
declineCheckpointMessageFuture.complete(declineCheckpoint.getReason());
+                               }
+                       };
+
+                       jobMaster.start(jobMasterId, testingTimeout).get();
+
+                       final String className = "UserException";
+                       final URLClassLoader userClassLoader = 
ClassLoaderUtils.compileAndLoadJava(
+                               temporaryFolder.newFolder(),
+                               className + ".java",
+                               String.format("public class %s extends 
RuntimeException { public %s() {super(\"UserMessage\");} }",
+                                       className,
+                                       className));
+
+                       Throwable userException = (Throwable) 
Class.forName(className, false, userClassLoader).newInstance();
+
+                       CompletableFuture<JobMasterGateway> jobMasterGateway =
+                               rpcService2.connect(jobMaster.getAddress(), 
jobMaster.getFencingToken(), JobMasterGateway.class);
+
+                       jobMasterGateway.thenAccept(gateway -> {
+                               gateway.declineCheckpoint(new DeclineCheckpoint(
+                                               jobGraph.getJobID(),
+                                               new ExecutionAttemptID(1, 1),
+                                               1,
+                                               userException
+                                       )
+                               );
+                       });
+
+                       Throwable throwable = 
declineCheckpointMessageFuture.get(testingTimeout.toMilliseconds(),
+                               TimeUnit.MILLISECONDS);
+                       assertThat(throwable, 
instanceOf(SerializedThrowable.class));
+                       assertThat(throwable.getMessage(), 
equalTo(userException.getMessage()));
+               } finally {
+                       RpcUtils.terminateRpcServices(testingTimeout, 
rpcService1, rpcService2);
+               }
+       }
+
        @Test
        public void testHeartbeatTimeoutWithTaskManager() throws Exception {
                final CompletableFuture<ResourceID> heartbeatResourceIdFuture = 
new CompletableFuture<>();
diff --git 
a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/utils/TestingJobMasterGateway.java
 
b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/utils/TestingJobMasterGateway.java
index c9c55a1da8f..f5f7f8e3415 100644
--- 
a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/utils/TestingJobMasterGateway.java
+++ 
b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/utils/TestingJobMasterGateway.java
@@ -41,6 +41,7 @@
 import org.apache.flink.runtime.jobmaster.SerializedInputSplit;
 import org.apache.flink.runtime.jobmaster.message.ClassloadingProps;
 import org.apache.flink.runtime.messages.Acknowledge;
+import org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint;
 import org.apache.flink.runtime.messages.webmonitor.JobDetails;
 import org.apache.flink.runtime.query.KvStateLocation;
 import org.apache.flink.runtime.registration.RegistrationResponse;
@@ -144,7 +145,7 @@
        private final Consumer<Tuple5<JobID, ExecutionAttemptID, Long, 
CheckpointMetrics, TaskStateSnapshot>> acknowledgeCheckpointConsumer;
 
        @Nonnull
-       private final Consumer<Tuple4<JobID, ExecutionAttemptID, Long, 
Throwable>> declineCheckpointConsumer;
+       private final Consumer<DeclineCheckpoint> declineCheckpointConsumer;
 
        @Nonnull
        private final Supplier<JobMasterId> fencingTokenSupplier;
@@ -183,7 +184,7 @@ public TestingJobMasterGateway(
                        @Nonnull Function<JobVertexID, 
CompletableFuture<OperatorBackPressureStatsResponse>> 
requestOperatorBackPressureStatsFunction,
                        @Nonnull BiConsumer<AllocationID, Throwable> 
notifyAllocationFailureConsumer,
                        @Nonnull Consumer<Tuple5<JobID, ExecutionAttemptID, 
Long, CheckpointMetrics, TaskStateSnapshot>> acknowledgeCheckpointConsumer,
-                       @Nonnull Consumer<Tuple4<JobID, ExecutionAttemptID, 
Long, Throwable>> declineCheckpointConsumer,
+                       @Nonnull Consumer<DeclineCheckpoint> 
declineCheckpointConsumer,
                        @Nonnull Supplier<JobMasterId> fencingTokenSupplier,
                        @Nonnull BiFunction<JobID, String, 
CompletableFuture<KvStateLocation>> requestKvStateLocationFunction,
                        @Nonnull Function<Tuple6<JobID, JobVertexID, 
KeyGroupRange, String, KvStateID, InetSocketAddress>, 
CompletableFuture<Acknowledge>> notifyKvStateRegisteredFunction,
@@ -335,8 +336,8 @@ public void acknowledgeCheckpoint(JobID jobID, 
ExecutionAttemptID executionAttem
        }
 
        @Override
-       public void declineCheckpoint(JobID jobID, ExecutionAttemptID 
executionAttemptID, long checkpointId, Throwable cause) {
-               declineCheckpointConsumer.accept(Tuple4.of(jobID, 
executionAttemptID, checkpointId, cause));
+       public void declineCheckpoint(DeclineCheckpoint declineCheckpoint) {
+               declineCheckpointConsumer.accept(declineCheckpoint);
        }
 
        @Override
diff --git 
a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/utils/TestingJobMasterGatewayBuilder.java
 
b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/utils/TestingJobMasterGatewayBuilder.java
index e40b752f248..b52df9ee052 100644
--- 
a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/utils/TestingJobMasterGatewayBuilder.java
+++ 
b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/utils/TestingJobMasterGatewayBuilder.java
@@ -40,6 +40,7 @@
 import org.apache.flink.runtime.jobmaster.SerializedInputSplit;
 import org.apache.flink.runtime.jobmaster.message.ClassloadingProps;
 import org.apache.flink.runtime.messages.Acknowledge;
+import org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint;
 import org.apache.flink.runtime.messages.webmonitor.JobDetails;
 import org.apache.flink.runtime.query.KvStateLocation;
 import org.apache.flink.runtime.query.UnknownKvStateLocation;
@@ -96,7 +97,7 @@
        private Function<JobVertexID, 
CompletableFuture<OperatorBackPressureStatsResponse>> 
requestOperatorBackPressureStatsFunction = ignored -> 
CompletableFuture.completedFuture(OperatorBackPressureStatsResponse.of(null));
        private BiConsumer<AllocationID, Throwable> 
notifyAllocationFailureConsumer = (ignoredA, ignoredB) -> {};
        private Consumer<Tuple5<JobID, ExecutionAttemptID, Long, 
CheckpointMetrics, TaskStateSnapshot>> acknowledgeCheckpointConsumer = ignored 
-> {};
-       private Consumer<Tuple4<JobID, ExecutionAttemptID, Long, Throwable>> 
declineCheckpointConsumer = ignored -> {};
+       private Consumer<DeclineCheckpoint> declineCheckpointConsumer = ignored 
-> {};
        private Supplier<JobMasterId> fencingTokenSupplier = () -> 
JOB_MASTER_ID;
        private BiFunction<JobID, String, CompletableFuture<KvStateLocation>> 
requestKvStateLocationFunction = (ignoredA, registrationName) -> 
FutureUtils.completedExceptionally(new 
UnknownKvStateLocation(registrationName));
        private Function<Tuple6<JobID, JobVertexID, KeyGroupRange, String, 
KvStateID, InetSocketAddress>, CompletableFuture<Acknowledge>> 
notifyKvStateRegisteredFunction = ignored -> 
CompletableFuture.completedFuture(Acknowledge.get());
@@ -222,7 +223,7 @@ public TestingJobMasterGatewayBuilder 
setAcknowledgeCheckpointConsumer(Consumer<
                return this;
        }
 
-       public TestingJobMasterGatewayBuilder 
setDeclineCheckpointConsumer(Consumer<Tuple4<JobID, ExecutionAttemptID, Long, 
Throwable>> declineCheckpointConsumer) {
+       public TestingJobMasterGatewayBuilder 
setDeclineCheckpointConsumer(Consumer<DeclineCheckpoint> 
declineCheckpointConsumer) {
                this.declineCheckpointConsumer = declineCheckpointConsumer;
                return this;
        }


 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


> ClassNotFoundException while deserializing user exceptions from checkpointing
> -----------------------------------------------------------------------------
>
>                 Key: FLINK-10419
>                 URL: https://issues.apache.org/jira/browse/FLINK-10419
>             Project: Flink
>          Issue Type: Bug
>          Components: Distributed Coordination, State Backends, Checkpointing
>    Affects Versions: 1.5.0, 1.5.1, 1.5.2, 1.5.3, 1.5.4, 1.6.0, 1.6.1, 1.7.0
>            Reporter: Nico Kruber
>            Assignee: Dawid Wysakowicz
>            Priority: Major
>              Labels: pull-request-available
>             Fix For: 1.5.6, 1.6.3, 1.7.0
>
>
> It seems that somewhere in the operator's failure handling, we hand a 
> user-code exception to the checkpoint coordinator via Java serialization but 
> it will then fail during the de-serialization because the class is not 
> available. This will result in the following error shadowing the real one:
> {code}
> java.lang.ClassNotFoundException: 
> org.apache.flink.streaming.connectors.kafka.FlinkKafka011Exception
>         at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
>         at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
>         at sun.misc.Launcher.loadClass(Launcher.java:338)
>         at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
>         at java.lang.Class.forName0(Native Method)
>         at java.lang.Class.forName(Class.java:348)
>         at 
> org.apache.flink.util.InstantiationUtil.resolveClass(InstantiationUtil.java:76)
>         at 
> java.io.ObjectInputStream.readNonProxyDesc(ObjectInputStream.java:1859)
>         at 
> java.io.ObjectInputStream.readClassDesc(ObjectInputStream.java:1745)
>         at 
> java.io.ObjectInputStream.readOrdinaryObject(ObjectInputStream.java:2033)
>         at java.io.ObjectInputStream.readObject0(ObjectInputStream.java:1567)
>         at 
> java.io.ObjectInputStream.defaultReadFields(ObjectInputStream.java:2278)
>         at 
> java.io.ObjectInputStream.defaultReadObject(ObjectInputStream.java:557)
>         at java.lang.Throwable.readObject(Throwable.java:914)
>         at sun.reflect.GeneratedMethodAccessor158.invoke(Unknown Source)
>         at 
> sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
>         at java.lang.reflect.Method.invoke(Method.java:498)
>         at 
> java.io.ObjectStreamClass.invokeReadObject(ObjectStreamClass.java:1158)
>         at 
> java.io.ObjectInputStream.readSerialData(ObjectInputStream.java:2169)
>         at 
> java.io.ObjectInputStream.readOrdinaryObject(ObjectInputStream.java:2060)
>         at java.io.ObjectInputStream.readObject0(ObjectInputStream.java:1567)
>         at java.io.ObjectInputStream.readObject(ObjectInputStream.java:427)
>         at 
> org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation.readObject(RemoteRpcInvocation.java:222)
>         at sun.reflect.GeneratedMethodAccessor7.invoke(Unknown Source)
>         at 
> sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
>         at java.lang.reflect.Method.invoke(Method.java:498)
>         at 
> java.io.ObjectStreamClass.invokeReadObject(ObjectStreamClass.java:1158)
>         at 
> java.io.ObjectInputStream.readSerialData(ObjectInputStream.java:2169)
>         at 
> java.io.ObjectInputStream.readOrdinaryObject(ObjectInputStream.java:2060)
>         at java.io.ObjectInputStream.readObject0(ObjectInputStream.java:1567)
>         at java.io.ObjectInputStream.readObject(ObjectInputStream.java:427)
>         at 
> org.apache.flink.util.InstantiationUtil.deserializeObject(InstantiationUtil.java:502)
>         at 
> org.apache.flink.util.InstantiationUtil.deserializeObject(InstantiationUtil.java:489)
>         at 
> org.apache.flink.util.InstantiationUtil.deserializeObject(InstantiationUtil.java:477)
>         at 
> org.apache.flink.util.SerializedValue.deserializeValue(SerializedValue.java:58)
>         at 
> org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation.deserializeMethodInvocation(RemoteRpcInvocation.java:118)
>         at 
> org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation.getMethodName(RemoteRpcInvocation.java:59)
>         at 
> org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:214)
>         at 
> org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:162)
>         at 
> org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:70)
>         at 
> org.apache.flink.runtime.rpc.akka.AkkaRpcActor.onReceive(AkkaRpcActor.java:142)
>         at 
> org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.onReceive(FencedAkkaRpcActor.java:40)
>         at 
> akka.actor.UntypedActor3728anonfun.applyOrElse(UntypedActor.scala:165)
>         at akka.actor.Actor.aroundReceive(Actor.scala:502)
>         at akka.actor.UntypedActor.aroundReceive(UntypedActor.scala:95)
>         at akka.actor.ActorCell.receiveMessage(ActorCell.scala:526)
>         at akka.actor.ActorCell.invoke(ActorCell.scala:495)
>         at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:257)
>         at akka.dispatch.Mailbox.run(Mailbox.scala:224)
>         at akka.dispatch.Mailbox.exec(Mailbox.scala:234)
>         at 
> scala.concurrent.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
>         at 
> scala.concurrent.forkjoin.ForkJoinPool.runTask(ForkJoinPool.java:1339)
>         at 
> scala.concurrent.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
>         at 
> scala.concurrent.forkjoin.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:107)
> {code}



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)

Reply via email to