Uses of Interface
org.apache.flink.queryablestate.network.stats.KvStateRequestStats
-
-
Uses of KvStateRequestStats in org.apache.flink.queryablestate.client.proxy
Constructors in org.apache.flink.queryablestate.client.proxy with parameters of type KvStateRequestStats Constructor Description KvStateClientProxyHandler(KvStateClientProxyImpl proxy, int queryExecutorThreads, MessageSerializer<KvStateRequest,KvStateResponse> serializer, KvStateRequestStats stats)
Create the handler used by theKvStateClientProxyImpl
.KvStateClientProxyImpl(String bindAddress, Iterator<Integer> bindPortIterator, Integer numEventLoopThreads, Integer numQueryThreads, KvStateRequestStats stats)
Creates the Queryable State Client Proxy. -
Uses of KvStateRequestStats in org.apache.flink.queryablestate.network
Constructors in org.apache.flink.queryablestate.network with parameters of type KvStateRequestStats Constructor 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. -
Uses of KvStateRequestStats in org.apache.flink.queryablestate.network.stats
Classes in org.apache.flink.queryablestate.network.stats that implement KvStateRequestStats Modifier and Type Class Description class
AtomicKvStateRequestStats
AtomicKvStateRequestStats
implementation.class
DisabledKvStateRequestStats
DisabledKvStateRequestStats
implementation. -
Uses of KvStateRequestStats in org.apache.flink.queryablestate.server
Constructors in org.apache.flink.queryablestate.server with parameters of type KvStateRequestStats Constructor Description KvStateServerHandler(KvStateServerImpl server, KvStateRegistry kvStateRegistry, MessageSerializer<KvStateInternalRequest,KvStateResponse> serializer, KvStateRequestStats stats)
Create the handler used by theKvStateServerImpl
.KvStateServerImpl(String bindAddress, Iterator<Integer> bindPortIterator, Integer numEventLoopThreads, Integer numQueryThreads, KvStateRegistry kvStateRegistry, KvStateRequestStats stats)
Creates the state server. -
Uses of KvStateRequestStats in org.apache.flink.runtime.query
Methods in org.apache.flink.runtime.query with parameters of type KvStateRequestStats Modifier and Type Method Description static KvStateClientProxy
QueryableStateUtils. createKvStateClientProxy(String address, Iterator<Integer> ports, int eventLoopThreads, int queryThreads, KvStateRequestStats stats)
Initializes theclient proxy
responsible for receiving requests from the external (to the cluster) client and forwarding them internally.static KvStateServer
QueryableStateUtils. createKvStateServer(String address, Iterator<Integer> ports, int eventLoopThreads, int queryThreads, KvStateRegistry kvStateRegistry, KvStateRequestStats stats)
Initializes theserver
responsible for sending the requested internal state to theclient proxy
.
-