Package | Description |
---|---|
org.apache.flink.queryablestate.client.proxy | |
org.apache.flink.queryablestate.messages | |
org.apache.flink.queryablestate.server |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<KvStateResponse> |
KvStateClientProxyHandler.handleRequest(long requestId,
KvStateRequest request) |
AbstractServerHandler<KvStateRequest,KvStateResponse> |
KvStateClientProxyImpl.initializeHandler() |
Constructor and Description |
---|
KvStateClientProxyHandler(KvStateClientProxyImpl proxy,
int queryExecutorThreads,
MessageSerializer<KvStateRequest,KvStateResponse> serializer,
KvStateRequestStats stats)
Create the handler used by the
KvStateClientProxyImpl . |
Modifier and Type | Method and Description |
---|---|
KvStateResponse |
KvStateResponse.KvStateResponseDeserializer.deserializeMessage(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf) |
Modifier and Type | Method and Description |
---|---|
MessageSerializer<KvStateInternalRequest,KvStateResponse> |
KvStateServerImpl.getSerializer() |
CompletableFuture<KvStateResponse> |
KvStateServerHandler.handleRequest(long requestId,
KvStateInternalRequest request) |
AbstractServerHandler<KvStateInternalRequest,KvStateResponse> |
KvStateServerImpl.initializeHandler() |
Constructor and Description |
---|
KvStateServerHandler(KvStateServerImpl server,
KvStateRegistry kvStateRegistry,
MessageSerializer<KvStateInternalRequest,KvStateResponse> serializer,
KvStateRequestStats stats)
Create the handler used by the
KvStateServerImpl . |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.