Package | Description |
---|---|
org.apache.flink.queryablestate.messages | |
org.apache.flink.queryablestate.network | |
org.apache.flink.queryablestate.network.messages |
Modifier and Type | Class and Description |
---|---|
class |
KvStateInternalRequest
The request to be forwarded by the
Queryable State Client Proxy to the State Server
of the Task Manager responsible for the requested state. |
class |
KvStateRequest
The request to be sent by the
Queryable State Client to the Client Proxy requesting a given state. |
class |
KvStateResponse
The response containing the (serialized) state sent by the
State Server to the Client Proxy ,
and then forwarded by the proxy to the original
Queryable State Client . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractServerBase<REQ extends MessageBody,RESP extends MessageBody>
The base class for every server in the queryable state module.
|
class |
AbstractServerBase<REQ extends MessageBody,RESP extends MessageBody>
The base class for every server in the queryable state module.
|
class |
AbstractServerHandler<REQ extends MessageBody,RESP extends MessageBody>
The base class of every handler used by an
AbstractServerBase . |
class |
AbstractServerHandler<REQ extends MessageBody,RESP extends MessageBody>
The base class of every handler used by an
AbstractServerBase . |
class |
Client<REQ extends MessageBody,RESP extends MessageBody>
The base class for every client in the queryable state module.
|
class |
Client<REQ extends MessageBody,RESP extends MessageBody>
The base class for every client in the queryable state module.
|
class |
ClientHandler<REQ extends MessageBody,RESP extends MessageBody>
The handler used by a
Client to handling incoming messages. |
class |
ClientHandler<REQ extends MessageBody,RESP extends MessageBody>
The handler used by a
Client to handling incoming messages. |
interface |
ClientHandlerCallback<RESP extends MessageBody>
Callback for
ClientHandler . |
Modifier and Type | Interface and Description |
---|---|
interface |
MessageDeserializer<M extends MessageBody>
A utility used to deserialize a
message . |
class |
MessageSerializer<REQ extends MessageBody,RESP extends MessageBody>
|
class |
MessageSerializer<REQ extends MessageBody,RESP extends MessageBody>
|
Modifier and Type | Method and Description |
---|---|
static <REQ extends MessageBody> |
MessageSerializer.serializeRequest(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBufAllocator alloc,
long requestId,
REQ request)
Serializes the request sent to the
AbstractServerBase . |
static <RESP extends MessageBody> |
MessageSerializer.serializeResponse(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBufAllocator alloc,
long requestId,
RESP response)
Serializes the response sent to the
Client . |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.