Package | Description |
---|---|
org.apache.flink.runtime.rpc | |
org.apache.flink.runtime.rpc.akka |
Modifier and Type | Field and Description |
---|---|
protected RpcServer |
RpcEndpoint.rpcServer
Interface to access the underlying rpc server.
|
Modifier and Type | Method and Description |
---|---|
<F extends Serializable> |
RpcService.fenceRpcServer(RpcServer rpcServer,
F fencingToken)
Fence the given RpcServer with the given fencing token.
|
<C extends RpcEndpoint & RpcGateway> |
RpcService.startServer(C rpcEndpoint)
Start a rpc server which forwards the remote procedure calls to the provided rpc endpoint.
|
Modifier and Type | Method and Description |
---|---|
<F extends Serializable> |
RpcService.fenceRpcServer(RpcServer rpcServer,
F fencingToken)
Fence the given RpcServer with the given fencing token.
|
void |
RpcService.stopServer(RpcServer selfGateway)
Stop the underlying rpc server of the provided self gateway.
|
Modifier and Type | Class and Description |
---|---|
class |
FencedAkkaInvocationHandler<F extends Serializable>
Fenced extension of the
AkkaInvocationHandler . |
Modifier and Type | Method and Description |
---|---|
<F extends Serializable> |
AkkaRpcService.fenceRpcServer(RpcServer rpcServer,
F fencingToken) |
<C extends RpcEndpoint & RpcGateway> |
AkkaRpcService.startServer(C rpcEndpoint) |
Modifier and Type | Method and Description |
---|---|
<F extends Serializable> |
AkkaRpcService.fenceRpcServer(RpcServer rpcServer,
F fencingToken) |
void |
AkkaRpcService.stopServer(RpcServer selfGateway) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.