Package | Description |
---|---|
org.apache.flink.queryablestate.client.proxy | |
org.apache.flink.queryablestate.network | |
org.apache.flink.queryablestate.server |
Constructor and Description |
---|
KvStateClientProxyHandler(KvStateClientProxyImpl proxy,
int queryExecutorThreads,
MessageSerializer<KvStateRequest,KvStateResponse> serializer,
KvStateRequestStats stats)
Create the handler used by the
KvStateClientProxyImpl . |
Constructor and Description |
---|
AbstractServerHandler(AbstractServerBase<REQ,RESP> server,
MessageSerializer<REQ,RESP> serializer,
KvStateRequestStats stats)
Create the handler.
|
Client(String clientName,
int numEventLoopThreads,
MessageSerializer<REQ,RESP> serializer,
KvStateRequestStats stats)
Creates a client with the specified number of event loop threads.
|
ClientHandler(String clientName,
MessageSerializer<REQ,RESP> serializer,
ClientHandlerCallback<RESP> callback)
Creates a handler with the callback.
|
Modifier and Type | Method and Description |
---|---|
MessageSerializer<KvStateInternalRequest,KvStateResponse> |
KvStateServerImpl.getSerializer() |
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.