Uses of Class
org.elasticsearch.cluster.node.DiscoveryNode

Packages that use DiscoveryNode
org.elasticsearch.action   
org.elasticsearch.action.admin.cluster.node.hotthreads   
org.elasticsearch.action.admin.cluster.node.info   
org.elasticsearch.action.admin.cluster.node.restart   
org.elasticsearch.action.admin.cluster.node.shutdown   
org.elasticsearch.action.admin.cluster.node.stats   
org.elasticsearch.action.search.type   
org.elasticsearch.action.support.nodes   
org.elasticsearch.client.transport   
org.elasticsearch.cluster   
org.elasticsearch.cluster.node   
org.elasticsearch.cluster.routing   
org.elasticsearch.cluster.routing.allocation   
org.elasticsearch.cluster.service   
org.elasticsearch.discovery   
org.elasticsearch.discovery.local   
org.elasticsearch.discovery.zen   
org.elasticsearch.discovery.zen.elect   
org.elasticsearch.discovery.zen.fd   
org.elasticsearch.discovery.zen.membership   
org.elasticsearch.discovery.zen.ping   
org.elasticsearch.discovery.zen.ping.unicast   
org.elasticsearch.gateway.local.state.meta   
org.elasticsearch.gateway.local.state.shards   
org.elasticsearch.indices.recovery   
org.elasticsearch.indices.store   
org.elasticsearch.jmx.action   
org.elasticsearch.node Allow to build a Node using NodeBuilder which is a node within the cluster. 
org.elasticsearch.river.cluster   
org.elasticsearch.river.routing   
org.elasticsearch.search.action   
org.elasticsearch.transport   
org.elasticsearch.transport.local   
org.elasticsearch.transport.netty   
 

Uses of DiscoveryNode in org.elasticsearch.action
 

Methods in org.elasticsearch.action with parameters of type DiscoveryNode
 ActionFuture<Response> TransportActionNodeProxy.execute(DiscoveryNode node, Request request)
           
 void TransportActionNodeProxy.execute(DiscoveryNode node, Request request, ActionListener<Response> listener)
           
 

Uses of DiscoveryNode in org.elasticsearch.action.admin.cluster.node.hotthreads
 

Constructors in org.elasticsearch.action.admin.cluster.node.hotthreads with parameters of type DiscoveryNode
NodeHotThreads(DiscoveryNode node, String hotThreads)
           
 

Uses of DiscoveryNode in org.elasticsearch.action.admin.cluster.node.info
 

Constructors in org.elasticsearch.action.admin.cluster.node.info with parameters of type DiscoveryNode
NodeInfo(String hostname, DiscoveryNode node, com.google.common.collect.ImmutableMap<String,String> serviceAttributes, Settings settings, OsInfo os, ProcessInfo process, JvmInfo jvm, ThreadPoolInfo threadPool, NetworkInfo network, TransportInfo transport, HttpInfo http)
           
 

Uses of DiscoveryNode in org.elasticsearch.action.admin.cluster.node.restart
 

Constructors in org.elasticsearch.action.admin.cluster.node.restart with parameters of type DiscoveryNode
NodesRestartResponse.NodeRestartResponse(DiscoveryNode node)
           
 

Uses of DiscoveryNode in org.elasticsearch.action.admin.cluster.node.shutdown
 

Methods in org.elasticsearch.action.admin.cluster.node.shutdown that return DiscoveryNode
 DiscoveryNode[] NodesShutdownResponse.getNodes()
           
 DiscoveryNode[] NodesShutdownResponse.nodes()
           
 

Constructors in org.elasticsearch.action.admin.cluster.node.shutdown with parameters of type DiscoveryNode
NodesShutdownResponse(ClusterName clusterName, DiscoveryNode[] nodes)
           
 

Uses of DiscoveryNode in org.elasticsearch.action.admin.cluster.node.stats
 

Constructors in org.elasticsearch.action.admin.cluster.node.stats with parameters of type DiscoveryNode
NodeStats(DiscoveryNode node, long timestamp, String hostname, NodeIndicesStats indices, OsStats os, ProcessStats process, JvmStats jvm, ThreadPoolStats threadPool, NetworkStats network, FsStats fs, TransportStats transport, HttpStats http)
           
 

Uses of DiscoveryNode in org.elasticsearch.action.search.type
 

Methods in org.elasticsearch.action.search.type with parameters of type DiscoveryNode
protected abstract  void TransportSearchTypeAction.BaseAsyncAction.sendExecuteFirstPhase(DiscoveryNode node, InternalSearchRequest request, SearchServiceListener<FirstResult> listener)
           
 

Uses of DiscoveryNode in org.elasticsearch.action.support.nodes
 

Methods in org.elasticsearch.action.support.nodes that return DiscoveryNode
 DiscoveryNode NodeOperationResponse.getNode()
          The node this information relates to.
 DiscoveryNode NodeOperationResponse.node()
          The node this information relates to.
 

Constructors in org.elasticsearch.action.support.nodes with parameters of type DiscoveryNode
NodeOperationResponse(DiscoveryNode node)
           
 

Uses of DiscoveryNode in org.elasticsearch.client.transport
 

Methods in org.elasticsearch.client.transport that return types with arguments of type DiscoveryNode
 com.google.common.collect.ImmutableList<DiscoveryNode> TransportClient.connectedNodes()
          Returns the current connected transport nodes that this client will use.
 com.google.common.collect.ImmutableList<DiscoveryNode> TransportClientNodesService.connectedNodes()
           
 com.google.common.collect.ImmutableList<DiscoveryNode> TransportClient.listedNodes()
          Returns the listed nodes in the transport client (ones added to it).
 com.google.common.collect.ImmutableList<DiscoveryNode> TransportClientNodesService.listedNodes()
           
 

Methods in org.elasticsearch.client.transport with parameters of type DiscoveryNode
 T TransportClientNodesService.NodeCallback.doWithNode(DiscoveryNode node)
           
 void TransportClientNodesService.NodeListenerCallback.doWithNode(DiscoveryNode node, ActionListener<Response> listener)
           
 

Constructor parameters in org.elasticsearch.client.transport with type arguments of type DiscoveryNode
TransportClientNodesService.RetryListener(TransportClientNodesService.NodeListenerCallback<Response> callback, ActionListener<Response> listener, com.google.common.collect.ImmutableList<DiscoveryNode> nodes, int index)
           
 

Uses of DiscoveryNode in org.elasticsearch.cluster
 

Methods in org.elasticsearch.cluster that return DiscoveryNode
 DiscoveryNode ClusterService.localNode()
          The local node.
 

Methods in org.elasticsearch.cluster with parameters of type DiscoveryNode
static ClusterState ClusterState.Builder.fromBytes(byte[] data, DiscoveryNode localNode)
           
static ClusterState ClusterState.Builder.readFrom(StreamInput in, DiscoveryNode localNode)
           
 

Uses of DiscoveryNode in org.elasticsearch.cluster.node
 

Fields in org.elasticsearch.cluster.node with type parameters of type DiscoveryNode
static com.google.common.collect.ImmutableList<DiscoveryNode> DiscoveryNode.EMPTY_LIST
           
 

Methods in org.elasticsearch.cluster.node that return DiscoveryNode
 DiscoveryNode DiscoveryNodes.findByAddress(TransportAddress address)
           
 DiscoveryNode DiscoveryNodes.get(String nodeId)
           
 DiscoveryNode DiscoveryNodes.getLocalNode()
           
 DiscoveryNode DiscoveryNodes.getMasterNode()
           
 DiscoveryNode DiscoveryNodes.localNode()
           
 DiscoveryNode DiscoveryNodes.masterNode()
           
 DiscoveryNode DiscoveryNodes.Delta.newMasterNode()
           
 DiscoveryNode DiscoveryNodes.Delta.previousMasterNode()
           
static DiscoveryNode DiscoveryNode.readNode(StreamInput in)
           
 

Methods in org.elasticsearch.cluster.node that return types with arguments of type DiscoveryNode
 com.google.common.collect.ImmutableList<DiscoveryNode> DiscoveryNodes.Delta.addedNodes()
           
 com.google.common.collect.ImmutableMap<String,DiscoveryNode> DiscoveryNodes.dataNodes()
           
 com.google.common.collect.ImmutableMap<String,DiscoveryNode> DiscoveryNodes.getDataNodes()
           
 com.google.common.collect.ImmutableMap<String,DiscoveryNode> DiscoveryNodes.getMasterNodes()
           
 com.google.common.collect.ImmutableMap<String,DiscoveryNode> DiscoveryNodes.getNodes()
           
 com.google.common.collect.UnmodifiableIterator<DiscoveryNode> DiscoveryNodes.iterator()
           
 com.google.common.collect.ImmutableMap<String,DiscoveryNode> DiscoveryNodes.masterAndDataNodes()
           
 com.google.common.collect.ImmutableMap<String,DiscoveryNode> DiscoveryNodes.masterNodes()
           
 com.google.common.collect.ImmutableMap<String,DiscoveryNode> DiscoveryNodes.nodes()
           
 com.google.common.collect.ImmutableList<DiscoveryNode> DiscoveryNodes.Delta.removedNodes()
           
 

Methods in org.elasticsearch.cluster.node with parameters of type DiscoveryNode
 boolean DiscoveryNodeFilters.match(DiscoveryNode node)
           
 DiscoveryNodes DiscoveryNodes.newNode(DiscoveryNode node)
           
 DiscoveryNodes.Builder DiscoveryNodes.Builder.put(DiscoveryNode node)
           
static DiscoveryNodes DiscoveryNodes.Builder.readFrom(StreamInput in, DiscoveryNode localNode)
           
 boolean DiscoveryNode.shouldConnectTo(DiscoveryNode otherNode)
          Should this node form a connection to the provided node.
 

Method parameters in org.elasticsearch.cluster.node with type arguments of type DiscoveryNode
 DiscoveryNodes.Builder DiscoveryNodes.Builder.putAll(Iterable<DiscoveryNode> nodes)
           
 

Constructors in org.elasticsearch.cluster.node with parameters of type DiscoveryNode
DiscoveryNodes.Delta(DiscoveryNode previousMasterNode, DiscoveryNode newMasterNode, String localNodeId, com.google.common.collect.ImmutableList<DiscoveryNode> removed, com.google.common.collect.ImmutableList<DiscoveryNode> added)
           
 

Constructor parameters in org.elasticsearch.cluster.node with type arguments of type DiscoveryNode
DiscoveryNodes.Delta(DiscoveryNode previousMasterNode, DiscoveryNode newMasterNode, String localNodeId, com.google.common.collect.ImmutableList<DiscoveryNode> removed, com.google.common.collect.ImmutableList<DiscoveryNode> added)
           
DiscoveryNodes.Delta(DiscoveryNode previousMasterNode, DiscoveryNode newMasterNode, String localNodeId, com.google.common.collect.ImmutableList<DiscoveryNode> removed, com.google.common.collect.ImmutableList<DiscoveryNode> added)
           
DiscoveryNodes.Delta(String localNodeId, com.google.common.collect.ImmutableList<DiscoveryNode> removed, com.google.common.collect.ImmutableList<DiscoveryNode> added)
           
DiscoveryNodes.Delta(String localNodeId, com.google.common.collect.ImmutableList<DiscoveryNode> removed, com.google.common.collect.ImmutableList<DiscoveryNode> added)
           
 

Uses of DiscoveryNode in org.elasticsearch.cluster.routing
 

Methods in org.elasticsearch.cluster.routing that return DiscoveryNode
 DiscoveryNode RoutingNode.node()
           
 

Constructors in org.elasticsearch.cluster.routing with parameters of type DiscoveryNode
RoutingNode(String nodeId, DiscoveryNode node)
           
RoutingNode(String nodeId, DiscoveryNode node, List<MutableShardRouting> shards)
           
 

Uses of DiscoveryNode in org.elasticsearch.cluster.routing.allocation
 

Methods in org.elasticsearch.cluster.routing.allocation that return DiscoveryNode
 DiscoveryNode AllocationExplanation.NodeExplanation.node()
           
 

Constructors in org.elasticsearch.cluster.routing.allocation with parameters of type DiscoveryNode
AllocationExplanation.NodeExplanation(DiscoveryNode node, String description)
           
 

Uses of DiscoveryNode in org.elasticsearch.cluster.service
 

Methods in org.elasticsearch.cluster.service that return DiscoveryNode
 DiscoveryNode InternalClusterService.localNode()
           
 

Uses of DiscoveryNode in org.elasticsearch.discovery
 

Methods in org.elasticsearch.discovery that return DiscoveryNode
 DiscoveryNode DiscoveryService.localNode()
           
 DiscoveryNode Discovery.localNode()
           
 

Uses of DiscoveryNode in org.elasticsearch.discovery.local
 

Methods in org.elasticsearch.discovery.local that return DiscoveryNode
 DiscoveryNode LocalDiscovery.localNode()
           
 

Uses of DiscoveryNode in org.elasticsearch.discovery.zen
 

Methods in org.elasticsearch.discovery.zen that return DiscoveryNode
 DiscoveryNode ZenDiscovery.localNode()
           
 

Uses of DiscoveryNode in org.elasticsearch.discovery.zen.elect
 

Methods in org.elasticsearch.discovery.zen.elect that return DiscoveryNode
 DiscoveryNode ElectMasterService.electMaster(Iterable<DiscoveryNode> nodes)
          Elects a new master out of the possible nodes, returning it.
 DiscoveryNode[] ElectMasterService.nextPossibleMasters(Iterable<DiscoveryNode> nodes, int numberOfPossibleMasters)
          Returns a list of the next possible masters.
 

Method parameters in org.elasticsearch.discovery.zen.elect with type arguments of type DiscoveryNode
 DiscoveryNode ElectMasterService.electMaster(Iterable<DiscoveryNode> nodes)
          Elects a new master out of the possible nodes, returning it.
 boolean ElectMasterService.hasEnoughMasterNodes(Iterable<DiscoveryNode> nodes)
           
 DiscoveryNode[] ElectMasterService.nextPossibleMasters(Iterable<DiscoveryNode> nodes, int numberOfPossibleMasters)
          Returns a list of the next possible masters.
 

Uses of DiscoveryNode in org.elasticsearch.discovery.zen.fd
 

Methods in org.elasticsearch.discovery.zen.fd that return DiscoveryNode
 DiscoveryNode MasterFaultDetection.masterNode()
           
 

Methods in org.elasticsearch.discovery.zen.fd with parameters of type DiscoveryNode
 void MasterFaultDetection.Listener.onMasterFailure(DiscoveryNode masterNode, String reason)
           
 void NodesFaultDetection.Listener.onNodeFailure(DiscoveryNode node, String reason)
           
 void MasterFaultDetection.restart(DiscoveryNode masterNode, String reason)
           
 void MasterFaultDetection.start(DiscoveryNode masterNode, String reason)
           
 

Uses of DiscoveryNode in org.elasticsearch.discovery.zen.membership
 

Methods in org.elasticsearch.discovery.zen.membership with parameters of type DiscoveryNode
 ClusterState MembershipAction.MembershipListener.onJoin(DiscoveryNode node)
           
 void MembershipAction.MembershipListener.onLeave(DiscoveryNode node)
           
 void MembershipAction.sendJoinRequest(DiscoveryNode masterNode, DiscoveryNode node)
           
 ClusterState MembershipAction.sendJoinRequestBlocking(DiscoveryNode masterNode, DiscoveryNode node, TimeValue timeout)
           
 void MembershipAction.sendLeaveRequest(DiscoveryNode masterNode, DiscoveryNode node)
           
 void MembershipAction.sendLeaveRequestBlocking(DiscoveryNode masterNode, DiscoveryNode node, TimeValue timeout)
           
 void MembershipAction.sendValidateJoinRequestBlocking(DiscoveryNode node, ClusterState clusterState, TimeValue timeout)
          Validates the join request, throwing a failure if it failed.
 

Uses of DiscoveryNode in org.elasticsearch.discovery.zen.ping
 

Methods in org.elasticsearch.discovery.zen.ping that return DiscoveryNode
 DiscoveryNode ZenPing.PingResponse.master()
           
 DiscoveryNode ZenPing.PingResponse.target()
           
 

Constructors in org.elasticsearch.discovery.zen.ping with parameters of type DiscoveryNode
ZenPing.PingResponse(DiscoveryNode target, DiscoveryNode master, ClusterName clusterName)
           
 

Uses of DiscoveryNode in org.elasticsearch.discovery.zen.ping.unicast
 

Methods in org.elasticsearch.discovery.zen.ping.unicast that return types with arguments of type DiscoveryNode
 List<DiscoveryNode> UnicastHostsProvider.buildDynamicNodes()
          Builds the dynamic list of unicast hosts to be used for unicast discovery.
 

Uses of DiscoveryNode in org.elasticsearch.gateway.local.state.meta
 

Constructors in org.elasticsearch.gateway.local.state.meta with parameters of type DiscoveryNode
TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState(DiscoveryNode node, MetaData metaData)
           
 

Uses of DiscoveryNode in org.elasticsearch.gateway.local.state.shards
 

Constructors in org.elasticsearch.gateway.local.state.shards with parameters of type DiscoveryNode
TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards(DiscoveryNode node, long version)
           
 

Uses of DiscoveryNode in org.elasticsearch.indices.recovery
 

Methods in org.elasticsearch.indices.recovery that return DiscoveryNode
 DiscoveryNode StartRecoveryRequest.sourceNode()
           
 DiscoveryNode StartRecoveryRequest.targetNode()
           
 

Constructors in org.elasticsearch.indices.recovery with parameters of type DiscoveryNode
RecoveryFailedException(ShardId shardId, DiscoveryNode sourceNode, DiscoveryNode targetNode, Throwable cause)
           
StartRecoveryRequest(ShardId shardId, DiscoveryNode sourceNode, DiscoveryNode targetNode, boolean markAsRelocated, Map<String,StoreFileMetaData> existingFiles)
          Start recovery request.
 

Uses of DiscoveryNode in org.elasticsearch.indices.store
 

Constructors in org.elasticsearch.indices.store with parameters of type DiscoveryNode
TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData(DiscoveryNode node, TransportNodesListShardStoreMetaData.StoreFilesMetaData storeFilesMetaData)
           
 

Uses of DiscoveryNode in org.elasticsearch.jmx.action
 

Methods in org.elasticsearch.jmx.action with parameters of type DiscoveryNode
 String GetJmxServiceUrlAction.obtainPublishUrl(DiscoveryNode node)
           
 

Uses of DiscoveryNode in org.elasticsearch.node
 

Constructors in org.elasticsearch.node with parameters of type DiscoveryNode
NodeClosedException(DiscoveryNode node)
           
 

Uses of DiscoveryNode in org.elasticsearch.river.cluster
 

Methods in org.elasticsearch.river.cluster with parameters of type DiscoveryNode
static boolean RiverNodeHelper.isRiverNode(DiscoveryNode node)
           
static boolean RiverNodeHelper.isRiverNode(DiscoveryNode node, RiverName riverName)
           
 

Uses of DiscoveryNode in org.elasticsearch.river.routing
 

Methods in org.elasticsearch.river.routing that return DiscoveryNode
 DiscoveryNode RiverRouting.node()
          The node the river is allocated to, null if its not allocated.
 

Uses of DiscoveryNode in org.elasticsearch.search.action
 

Methods in org.elasticsearch.search.action with parameters of type DiscoveryNode
 void SearchServiceTransportAction.sendExecuteDfs(DiscoveryNode node, InternalSearchRequest request, SearchServiceListener<DfsSearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteFetch(DiscoveryNode node, FetchSearchRequest request, SearchServiceListener<FetchSearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteFetch(DiscoveryNode node, InternalScrollSearchRequest request, SearchServiceListener<QueryFetchSearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteFetch(DiscoveryNode node, InternalSearchRequest request, SearchServiceListener<QueryFetchSearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteFetch(DiscoveryNode node, QuerySearchRequest request, SearchServiceListener<QueryFetchSearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteQuery(DiscoveryNode node, InternalScrollSearchRequest request, SearchServiceListener<QuerySearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteQuery(DiscoveryNode node, InternalSearchRequest request, SearchServiceListener<QuerySearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteQuery(DiscoveryNode node, QuerySearchRequest request, SearchServiceListener<QuerySearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteScan(DiscoveryNode node, InternalScrollSearchRequest request, SearchServiceListener<QueryFetchSearchResult> listener)
           
 void SearchServiceTransportAction.sendExecuteScan(DiscoveryNode node, InternalSearchRequest request, SearchServiceListener<QuerySearchResult> listener)
           
 void SearchServiceTransportAction.sendFreeContext(DiscoveryNode node, long contextId)
           
 

Uses of DiscoveryNode in org.elasticsearch.transport
 

Methods in org.elasticsearch.transport that return DiscoveryNode
 DiscoveryNode ConnectTransportException.node()
           
 

Methods in org.elasticsearch.transport with parameters of type DiscoveryNode
 void Transport.connectToNode(DiscoveryNode node)
          Connects to the given node, if already connected, does nothing.
 void TransportService.connectToNode(DiscoveryNode node)
           
 void Transport.connectToNodeLight(DiscoveryNode node)
          Connects to a node in a light manner.
 void TransportService.connectToNodeLight(DiscoveryNode node)
           
 void Transport.disconnectFromNode(DiscoveryNode node)
          Disconnected from the given node, if not connected, will do nothing.
 void TransportService.disconnectFromNode(DiscoveryNode node)
           
 boolean Transport.nodeConnected(DiscoveryNode node)
          Returns true if the node is connected.
 boolean TransportService.nodeConnected(DiscoveryNode node)
           
 void TransportConnectionListener.onNodeConnected(DiscoveryNode node)
           
 void TransportConnectionListener.onNodeDisconnected(DiscoveryNode node)
           
 void TransportServiceAdapter.raiseNodeConnected(DiscoveryNode node)
           
 void TransportServiceAdapter.raiseNodeDisconnected(DiscoveryNode node)
           
<T extends Streamable>
void
Transport.sendRequest(DiscoveryNode node, long requestId, String action, Streamable message, TransportRequestOptions options)
          Sends the request to the node.
<T extends Streamable>
void
TransportService.sendRequest(DiscoveryNode node, String action, Streamable message, TransportRequestOptions options, TransportResponseHandler<T> handler)
           
<T extends Streamable>
void
TransportService.sendRequest(DiscoveryNode node, String action, Streamable message, TransportResponseHandler<T> handler)
           
<T extends Streamable>
TransportFuture<T>
TransportService.submitRequest(DiscoveryNode node, String action, Streamable message, TransportRequestOptions options, TransportResponseHandler<T> handler)
           
<T extends Streamable>
TransportFuture<T>
TransportService.submitRequest(DiscoveryNode node, String action, Streamable message, TransportResponseHandler<T> handler)
           
 

Constructors in org.elasticsearch.transport with parameters of type DiscoveryNode
ConnectTransportException(DiscoveryNode node, String msg)
           
ConnectTransportException(DiscoveryNode node, String msg, String action)
           
ConnectTransportException(DiscoveryNode node, String msg, String action, Throwable cause)
           
ConnectTransportException(DiscoveryNode node, String msg, Throwable cause)
           
NodeDisconnectedException(DiscoveryNode node, String action)
           
NodeNotConnectedException(DiscoveryNode node, String msg)
           
NodeNotConnectedException(DiscoveryNode node, String msg, Throwable cause)
           
ReceiveTimeoutTransportException(DiscoveryNode node, String action, String msg)
           
SendRequestTransportException(DiscoveryNode node, String action, Throwable cause)
           
 

Uses of DiscoveryNode in org.elasticsearch.transport.local
 

Methods in org.elasticsearch.transport.local with parameters of type DiscoveryNode
 void LocalTransport.connectToNode(DiscoveryNode node)
           
 void LocalTransport.connectToNodeLight(DiscoveryNode node)
           
 void LocalTransport.disconnectFromNode(DiscoveryNode node)
           
 boolean LocalTransport.nodeConnected(DiscoveryNode node)
           
<T extends Streamable>
void
LocalTransport.sendRequest(DiscoveryNode node, long requestId, String action, Streamable message, TransportRequestOptions options)
           
 

Uses of DiscoveryNode in org.elasticsearch.transport.netty
 

Methods in org.elasticsearch.transport.netty with parameters of type DiscoveryNode
 void NettyTransport.connectToNode(DiscoveryNode node)
           
 void NettyTransport.connectToNode(DiscoveryNode node, boolean light)
           
 void NettyTransport.connectToNodeLight(DiscoveryNode node)
           
 void NettyTransport.disconnectFromNode(DiscoveryNode node)
           
 boolean NettyTransport.nodeConnected(DiscoveryNode node)
           
<T extends Streamable>
void
NettyTransport.sendRequest(DiscoveryNode node, long requestId, String action, Streamable message, TransportRequestOptions options)
           
 



Copyright © 2009-2012. All Rights Reserved.