Package | Description |
---|---|
org.apache.flink.runtime.rpc | |
org.apache.flink.runtime.rpc.pekko |
Modifier and Type | Field and Description |
---|---|
protected RpcServer |
RpcEndpoint.rpcServer
Interface to access the underlying rpc server.
|
Modifier and Type | Method and Description |
---|---|
<C extends RpcEndpoint & RpcGateway> |
RpcService.startServer(C rpcEndpoint,
Map<String,String> loggingContext)
Start a rpc server which forwards the remote procedure calls to the provided rpc endpoint.
|
Modifier and Type | Method and Description |
---|---|
<C extends RpcGateway> |
RpcService.getSelfGateway(Class<C> selfGatewayType,
RpcServer rpcServer)
Returns a self gateway of the specified type which can be used to issue asynchronous calls
against the RpcEndpoint.
|
void |
RpcService.stopServer(RpcServer selfGateway)
Stop the underlying rpc server of the provided self gateway.
|
Modifier and Type | Class and Description |
---|---|
class |
FencedPekkoInvocationHandler<F extends Serializable>
Fenced extension of the
PekkoInvocationHandler . |
Modifier and Type | Method and Description |
---|---|
<C extends RpcEndpoint & RpcGateway> |
PekkoRpcService.startServer(C rpcEndpoint,
Map<String,String> loggingContext) |
Modifier and Type | Method and Description |
---|---|
<C extends RpcGateway> |
PekkoRpcService.getSelfGateway(Class<C> selfGatewayType,
RpcServer rpcServer) |
void |
PekkoRpcService.stopServer(RpcServer selfGateway) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.