Class RpcTaskOperatorEventGateway
- java.lang.Object
-
- org.apache.flink.runtime.taskexecutor.rpc.RpcTaskOperatorEventGateway
-
- All Implemented Interfaces:
TaskOperatorEventGateway
public class RpcTaskOperatorEventGateway extends Object implements TaskOperatorEventGateway
An OperatorEventSender that calls the RPC gatewayJobMasterOperatorEventGateway
to send the messages to the coordinator.
-
-
Constructor Summary
Constructors Constructor Description RpcTaskOperatorEventGateway(JobMasterOperatorEventGateway rpcGateway, ExecutionAttemptID taskExecutionId, Consumer<Throwable> errorHandler)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
sendOperatorEventToCoordinator(OperatorID operator, SerializedValue<OperatorEvent> event)
Sends an event from the operator (identified by the given operator ID) to the operator coordinator (identified by the same ID).CompletableFuture<CoordinationResponse>
sendRequestToCoordinator(OperatorID operator, SerializedValue<CoordinationRequest> request)
Sends a request from current operator to a specified operator coordinator which is identified by the given operator ID and return the response.
-
-
-
Constructor Detail
-
RpcTaskOperatorEventGateway
public RpcTaskOperatorEventGateway(JobMasterOperatorEventGateway rpcGateway, ExecutionAttemptID taskExecutionId, Consumer<Throwable> errorHandler)
-
-
Method Detail
-
sendOperatorEventToCoordinator
public void sendOperatorEventToCoordinator(OperatorID operator, SerializedValue<OperatorEvent> event)
Description copied from interface:TaskOperatorEventGateway
Sends an event from the operator (identified by the given operator ID) to the operator coordinator (identified by the same ID).- Specified by:
sendOperatorEventToCoordinator
in interfaceTaskOperatorEventGateway
-
sendRequestToCoordinator
public CompletableFuture<CoordinationResponse> sendRequestToCoordinator(OperatorID operator, SerializedValue<CoordinationRequest> request)
Description copied from interface:TaskOperatorEventGateway
Sends a request from current operator to a specified operator coordinator which is identified by the given operator ID and return the response.- Specified by:
sendRequestToCoordinator
in interfaceTaskOperatorEventGateway
-
-