Package | Description |
---|---|
org.apache.flink.queryablestate.messages | |
org.apache.flink.queryablestate.server |
Modifier and Type | Method and Description |
---|---|
KvStateInternalRequest |
KvStateInternalRequest.KvStateInternalRequestDeserializer.deserializeMessage(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf) |
Modifier and Type | Method and Description |
---|---|
MessageSerializer<KvStateInternalRequest,KvStateResponse> |
KvStateServerImpl.getSerializer() |
AbstractServerHandler<KvStateInternalRequest,KvStateResponse> |
KvStateServerImpl.initializeHandler() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<KvStateResponse> |
KvStateServerHandler.handleRequest(long requestId,
KvStateInternalRequest request) |
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.