Package | Description |
---|---|
org.apache.flink.queryablestate.client.proxy | |
org.apache.flink.queryablestate.server | |
org.apache.flink.runtime.io.network | |
org.apache.flink.runtime.query |
Modifier and Type | Class and Description |
---|---|
class |
KvStateClientProxyImpl
The default implementation of the
KvStateClientProxy . |
Modifier and Type | Class and Description |
---|---|
class |
KvStateServerImpl
The default implementation of the
KvStateServer . |
Modifier and Type | Method and Description |
---|---|
KvStateServer |
NetworkEnvironment.getKvStateServer() |
Constructor and Description |
---|
NetworkEnvironment(NetworkBufferPool networkBufferPool,
ConnectionManager connectionManager,
ResultPartitionManager resultPartitionManager,
TaskEventDispatcher taskEventDispatcher,
KvStateRegistry kvStateRegistry,
KvStateServer kvStateServer,
KvStateClientProxy kvStateClientProxy,
IOManager.IOMode defaultIOMode,
int partitionRequestInitialBackoff,
int partitionRequestMaxBackoff,
int networkBuffersPerChannel,
int extraNetworkBuffersPerGate,
boolean enableCreditBased) |
Modifier and Type | Interface and Description |
---|---|
interface |
KvStateClientProxy
An interface for the Queryable State Client Proxy running on each Task Manager in the cluster.
|
Modifier and Type | Method and Description |
---|---|
static KvStateServer |
QueryableStateUtils.createKvStateServer(InetAddress address,
Iterator<Integer> ports,
int eventLoopThreads,
int queryThreads,
KvStateRegistry kvStateRegistry,
KvStateRequestStats stats)
Initializes the
server responsible for sending the
requested internal state to the client proxy . |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.