Uses of Interface
org.apache.flink.runtime.operators.coordination.CoordinationResponse
-
-
Uses of CoordinationResponse in org.apache.flink.client.deployment
Methods in org.apache.flink.client.deployment that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
ClusterClientJobClientAdapter. sendCoordinationRequest(OperatorID operatorId, CoordinationRequest request)
-
Uses of CoordinationResponse in org.apache.flink.client.deployment.application
Methods in org.apache.flink.client.deployment.application that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
EmbeddedJobClient. sendCoordinationRequest(OperatorID operatorId, CoordinationRequest request)
-
Uses of CoordinationResponse in org.apache.flink.client.program
Methods in org.apache.flink.client.program that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
ClusterClient. sendCoordinationRequest(JobID jobId, OperatorID operatorId, CoordinationRequest request)
Sends out a request to a specified coordinator and return the response.CompletableFuture<CoordinationResponse>
MiniClusterClient. sendCoordinationRequest(JobID jobId, OperatorID operatorId, CoordinationRequest request)
-
Uses of CoordinationResponse in org.apache.flink.client.program.rest
Methods in org.apache.flink.client.program.rest that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
RestClusterClient. sendCoordinationRequest(JobID jobId, OperatorID operatorId, CoordinationRequest request)
-
Uses of CoordinationResponse in org.apache.flink.runtime.dispatcher
Methods in org.apache.flink.runtime.dispatcher that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
Dispatcher. deliverCoordinationRequestToCoordinator(JobID jobId, OperatorID operatorId, SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)
-
Uses of CoordinationResponse in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
TaskOperatorEventGateway. 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. -
Uses of CoordinationResponse in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
JobMaster. deliverCoordinationRequestToCoordinator(OperatorID operatorId, SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)
CompletableFuture<CoordinationResponse>
JobMasterGateway. deliverCoordinationRequestToCoordinator(OperatorID operatorId, SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)
Deliver a coordination request to a specified coordinator and return the response.CompletableFuture<CoordinationResponse>
JobMaster. sendRequestToCoordinator(OperatorID operatorID, SerializedValue<CoordinationRequest> serializedRequest)
CompletableFuture<CoordinationResponse>
JobMasterOperatorEventGateway. sendRequestToCoordinator(OperatorID operatorID, SerializedValue<CoordinationRequest> request)
-
Uses of CoordinationResponse in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
MiniCluster. deliverCoordinationRequestToCoordinator(JobID jobId, OperatorID operatorId, SerializedValue<CoordinationRequest> serializedRequest)
CompletableFuture<CoordinationResponse>
MiniClusterJobClient. sendCoordinationRequest(OperatorID operatorId, CoordinationRequest request)
-
Uses of CoordinationResponse in org.apache.flink.runtime.operators.coordination
Methods in org.apache.flink.runtime.operators.coordination that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
CoordinationRequestHandler. handleCoordinationRequest(CoordinationRequest request)
Called when receiving a request from the client or operator.CompletableFuture<CoordinationResponse>
CoordinationRequestGateway. sendCoordinationRequest(OperatorID operatorId, CoordinationRequest request)
Send out a request to a specified coordinator and return the response. -
Uses of CoordinationResponse in org.apache.flink.runtime.rest.messages.job.coordination
Methods in org.apache.flink.runtime.rest.messages.job.coordination that return types with arguments of type CoordinationResponse Modifier and Type Method Description SerializedValue<CoordinationResponse>
ClientCoordinationResponseBody. getSerializedCoordinationResponse()
Constructor parameters in org.apache.flink.runtime.rest.messages.job.coordination with type arguments of type CoordinationResponse Constructor Description ClientCoordinationResponseBody(SerializedValue<CoordinationResponse> serializedCoordinationResponse)
-
Uses of CoordinationResponse in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
DefaultOperatorCoordinatorHandler. deliverCoordinationRequestToCoordinator(OperatorID operator, CoordinationRequest request)
CompletableFuture<CoordinationResponse>
OperatorCoordinatorHandler. deliverCoordinationRequestToCoordinator(OperatorID operator, CoordinationRequest request)
Deliver coordination request from the client to the coordinator.CompletableFuture<CoordinationResponse>
SchedulerBase. deliverCoordinationRequestToCoordinator(OperatorID operator, CoordinationRequest request)
CompletableFuture<CoordinationResponse>
SchedulerNG. deliverCoordinationRequestToCoordinator(OperatorID operator, CoordinationRequest request)
Delivers a coordination request to theOperatorCoordinator
with the givenOperatorID
and returns the coordinator's response. -
Uses of CoordinationResponse in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
AdaptiveScheduler. deliverCoordinationRequestToCoordinator(OperatorID operator, CoordinationRequest request)
-
Uses of CoordinationResponse in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
RpcTaskOperatorEventGateway. sendRequestToCoordinator(OperatorID operator, SerializedValue<CoordinationRequest> request)
-
Uses of CoordinationResponse in org.apache.flink.runtime.webmonitor
Methods in org.apache.flink.runtime.webmonitor that return types with arguments of type CoordinationResponse Modifier and Type Method Description default CompletableFuture<CoordinationResponse>
RestfulGateway. deliverCoordinationRequestToCoordinator(JobID jobId, OperatorID operatorId, SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)
Deliver a coordination request to a specified coordinator and return the response. -
Uses of CoordinationResponse in org.apache.flink.streaming.api.operators.collect
Classes in org.apache.flink.streaming.api.operators.collect that implement CoordinationResponse Modifier and Type Class Description class
CollectCoordinationResponse
ACoordinationResponse
from the coordinator containing the required batch or new results and other necessary information in serialized form.Methods in org.apache.flink.streaming.api.operators.collect that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
CollectSinkOperatorCoordinator. handleCoordinationRequest(CoordinationRequest request)
-
Uses of CoordinationResponse in org.apache.flink.table.runtime.operators.dynamicfiltering
Methods in org.apache.flink.table.runtime.operators.dynamicfiltering that return types with arguments of type CoordinationResponse Modifier and Type Method Description CompletableFuture<CoordinationResponse>
DynamicFilteringDataCollectorOperatorCoordinator. handleCoordinationRequest(CoordinationRequest request)
-