Package | Description |
---|---|
org.apache.ignite |
Contains entry-point Ignite & HPC APIs.
|
org.apache.ignite.cache.affinity |
Contains cache node affinity implementations.
|
org.apache.ignite.cache.affinity.rendezvous |
Contains HRW-based cache affinity for partitioned cache.
|
org.apache.ignite.cluster |
Contains cluster-related classes.
|
org.apache.ignite.compute |
Contains Compute Grid functionality.
|
org.apache.ignite.compute.gridify.aop |
Contains common classes for different AOP providers.
|
org.apache.ignite.configuration |
Contains configuration-related classes.
|
org.apache.ignite.events |
Contains Event Subscription functionality together with various events emitted by Ignite.
|
org.apache.ignite.hadoop |
Contains Hadoop Accelerator APIs.
|
org.apache.ignite.hadoop.mapreduce |
Ignite Hadoop Accelerator map-reduce classes.
|
org.apache.ignite.hadoop.planner |
Ignite Hadoop Accelerator planner classes.
|
org.apache.ignite.igfs.mapreduce |
Contains APIs for In-Memory MapReduce over IGFS.
|
org.apache.ignite.ml.dataset.impl.cache.util |
Contains util classes used in cache based implementation of dataset.
|
org.apache.ignite.ml.genetic |
Root GA package (GA Grid)
|
org.apache.ignite.platform.dotnet |
Contains .Net platform-related classes.
|
org.apache.ignite.plugin |
Contains plugins management API.
|
org.apache.ignite.services |
Contains main Managed Services APIs.
|
org.apache.ignite.spi |
Contains common classes and interfaces for SPI implementations.
|
org.apache.ignite.spi.communication |
Contains APIs for grid communication SPI.
|
org.apache.ignite.spi.communication.tcp |
Contains default TCP/IP-based implementation for communication SPI.
|
org.apache.ignite.spi.discovery |
Contains APIs for topology manager SPI.
|
org.apache.ignite.spi.discovery.tcp |
Contains default TCP/IP implementation for discovery SPI.
|
org.apache.ignite.spi.discovery.zk |
Contains Zookeeper Discovery Spi classes and interfaces.
|
org.apache.ignite.spi.failover |
Contains APIs for failover SPI.
|
org.apache.ignite.spi.failover.always |
Contains default "always" failover SPI.
|
org.apache.ignite.spi.failover.jobstealing |
Contains job stealing failover SPI.
|
org.apache.ignite.spi.failover.never |
Contains "never" failover SPI.
|
org.apache.ignite.spi.indexing |
Contains APIs for indexing SPI.
|
org.apache.ignite.spi.loadbalancing |
Contains APIs for load balancing SPI.
|
org.apache.ignite.spi.loadbalancing.adaptive |
Contains adaptive load balancing SPI.
|
org.apache.ignite.spi.loadbalancing.roundrobin |
Contains default round-robin implementation for load balancing SPI.
|
org.apache.ignite.spi.loadbalancing.weightedrandom |
Contains weighted random-base implementation for load balancing SPI.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
IgniteCluster.localNode()
Gets local grid node.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
IgniteCluster.topology(long topVer)
Gets a topology by version.
|
Modifier and Type | Method and Description |
---|---|
@Nullable ClusterNode |
Affinity.mapKeyToNode(K key)
This method provides ability to detect to which primary node the given key
is mapped.
|
ClusterNode |
Affinity.mapPartitionToNode(int part)
Gets primary node for the given partition.
|
Modifier and Type | Method and Description |
---|---|
List<List<ClusterNode>> |
AffinityFunction.assignPartitions(AffinityFunctionContext affCtx)
Gets affinity nodes for a partition.
|
List<ClusterNode> |
AffinityFunctionContext.currentTopologySnapshot()
Gets current topology snapshot.
|
Map<ClusterNode,Collection<K>> |
Affinity.mapKeysToNodes(Collection<? extends K> keys)
This method provides ability to detect which keys are mapped to which nodes.
|
Collection<ClusterNode> |
Affinity.mapKeyToPrimaryAndBackups(K key)
Gets primary and backup nodes for the key.
|
Map<Integer,ClusterNode> |
Affinity.mapPartitionsToNodes(Collection<Integer> parts)
Gets primary nodes for the given partitions.
|
Collection<ClusterNode> |
Affinity.mapPartitionToPrimaryAndBackups(int part)
Gets primary and backup nodes for partition.
|
Modifier and Type | Method and Description |
---|---|
int[] |
Affinity.allPartitions(ClusterNode n)
Gets partition ids for which given cluster node has any ownership
(either primary or backup).
|
int[] |
Affinity.backupPartitions(ClusterNode n)
Gets partition ids for which given cluster node has backup ownership.
|
boolean |
Affinity.isBackup(ClusterNode n,
K key)
Returns
true if local node is one of the backup nodes for given key. |
boolean |
Affinity.isPrimary(ClusterNode n,
K key)
Returns
true if given node is the primary node for given key. |
boolean |
Affinity.isPrimaryOrBackup(ClusterNode n,
K key)
Returns
true if local node is primary or one of the backup nodes
This method is essentially equivalent to calling
"Affinity.isPrimary(ClusterNode, Object) || Affinity.isBackup(ClusterNode, Object) )",
however it is more efficient as it makes both checks at once. |
int[] |
Affinity.primaryPartitions(ClusterNode n)
Gets partition ids for which the given cluster node has primary ownership.
|
Modifier and Type | Method and Description |
---|---|
List<ClusterNode> |
RendezvousAffinityFunction.assignPartition(int part,
List<ClusterNode> nodes,
int backups,
@Nullable Map<UUID,Collection<ClusterNode>> neighborhoodCache)
Returns collection of nodes (primary first) for specified partition.
|
List<List<ClusterNode>> |
RendezvousAffinityFunction.assignPartitions(AffinityFunctionContext affCtx)
Gets affinity nodes for a partition.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ClusterNodeAttributeAffinityBackupFilter.apply(ClusterNode candidate,
List<ClusterNode> previouslySelected)
Defines a predicate which returns
true if a node is acceptable for a backup
or false otherwise. |
Object |
RendezvousAffinityFunction.resolveNodeHash(ClusterNode node)
Resolves node hash.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ClusterNodeAttributeAffinityBackupFilter.apply(ClusterNode candidate,
List<ClusterNode> previouslySelected)
Defines a predicate which returns
true if a node is acceptable for a backup
or false otherwise. |
List<ClusterNode> |
RendezvousAffinityFunction.assignPartition(int part,
List<ClusterNode> nodes,
int backups,
@Nullable Map<UUID,Collection<ClusterNode>> neighborhoodCache)
Returns collection of nodes (primary first) for specified partition.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
ClusterGroup.node()
Gets first node from the list of nodes in this cluster group.
|
ClusterNode |
ClusterGroup.node(UUID nid)
Gets a node for given ID from this cluster group.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
ClusterGroup.nodes()
Gets the read-only collection of nodes in this cluster group.
|
IgnitePredicate<ClusterNode> |
ClusterGroup.predicate()
Gets predicate that defines a subset of nodes for this cluster group.
|
Modifier and Type | Method and Description |
---|---|
ClusterGroup |
ClusterGroup.forHost(ClusterNode node)
Gets cluster group consisting from the nodes in this cluster group residing on the
same host as the given node.
|
ClusterGroup |
ClusterGroup.forNode(ClusterNode node,
ClusterNode... nodes)
Creates a cluster group for the given node.
|
ClusterGroup |
ClusterGroup.forNode(ClusterNode node,
ClusterNode... nodes)
Creates a cluster group for the given node.
|
ClusterGroup |
ClusterGroup.forOthers(ClusterNode node,
ClusterNode... nodes)
Creates a cluster group for nodes other than the given nodes.
|
ClusterGroup |
ClusterGroup.forOthers(ClusterNode node,
ClusterNode... nodes)
Creates a cluster group for nodes other than the given nodes.
|
Modifier and Type | Method and Description |
---|---|
ClusterGroup |
ClusterGroup.forNodes(Collection<? extends ClusterNode> nodes)
Creates a cluster group over a given set of nodes.
|
ClusterGroup |
ClusterGroup.forPredicate(IgnitePredicate<ClusterNode> p)
Creates a new cluster group which includes all nodes that pass the given predicate filter.
|
Modifier and Type | Method and Description |
---|---|
@Nullable ClusterNode |
ComputeLoadBalancer.getBalancedNode(ComputeJob job,
@Nullable Collection<ClusterNode> exclNodes)
Gets the next balanced node according to the underlying load balancing policy.
|
ClusterNode |
ComputeJobResult.getNode()
Gets node this job executed on.
|
Modifier and Type | Method and Description |
---|---|
Map<? extends ComputeJob,ClusterNode> |
ComputeTaskSplitAdapter.map(List<ClusterNode> subgrid,
T arg)
This method is called to map or split grid task into multiple grid jobs.
|
Modifier and Type | Method and Description |
---|---|
void |
ComputeTaskContinuousMapper.send(ComputeJob job,
ClusterNode node)
Sends given job to a specific grid node.
|
Modifier and Type | Method and Description |
---|---|
@Nullable Map<? extends ComputeJob,ClusterNode> |
ComputeTask.map(List<ClusterNode> subgrid,
T arg)
This method is called to map or split grid task into multiple grid jobs.
|
Map<? extends ComputeJob,ClusterNode> |
ComputeTaskSplitAdapter.map(List<ClusterNode> subgrid,
T arg)
This method is called to map or split grid task into multiple grid jobs.
|
void |
ComputeTaskContinuousMapper.send(Map<? extends ComputeJob,ClusterNode> mappedJobs)
Sends collection of grid jobs to assigned nodes.
|
Modifier and Type | Method and Description |
---|---|
Map<? extends ComputeJob,ClusterNode> |
GridifyDefaultTask.map(List<ClusterNode> subgrid,
GridifyArgument arg)
This method is called to map or split grid task into multiple grid jobs.
|
Map<? extends ComputeJob,ClusterNode> |
GridifyDefaultRangeTask.map(List<ClusterNode> subgrid,
org.apache.ignite.internal.util.gridify.GridifyRangeArgument arg)
This method is called to map or split grid task into multiple grid jobs.
|
Modifier and Type | Method and Description |
---|---|
Map<? extends ComputeJob,ClusterNode> |
GridifyDefaultTask.map(List<ClusterNode> subgrid,
GridifyArgument arg)
This method is called to map or split grid task into multiple grid jobs.
|
Map<? extends ComputeJob,ClusterNode> |
GridifyDefaultRangeTask.map(List<ClusterNode> subgrid,
org.apache.ignite.internal.util.gridify.GridifyRangeArgument arg)
This method is called to map or split grid task into multiple grid jobs.
|
Modifier and Type | Field and Description |
---|---|
static IgnitePredicate<ClusterNode> |
CacheConfiguration.ALL_NODES
Filter that accepts all nodes.
|
Modifier and Type | Method and Description |
---|---|
List<List<ClusterNode>> |
CommunicationFailureContext.cacheAffinity(String cacheName) |
List<List<ClusterNode>> |
CommunicationFailureContext.cachePartitionOwners(String cacheName) |
IgnitePredicate<ClusterNode> |
CacheConfiguration.getNodeFilter()
Gets filter which determines on what nodes the cache should be started.
|
IgnitePredicate<ClusterNode> |
CollectionConfiguration.getNodeFilter() |
List<ClusterNode> |
CommunicationFailureContext.topologySnapshot() |
Modifier and Type | Method and Description |
---|---|
boolean |
CacheConfiguration.IgniteAllNodesPredicate.apply(ClusterNode node)
Predicate body.
|
boolean |
CommunicationFailureContext.connectionAvailable(ClusterNode node1,
ClusterNode node2) |
void |
CommunicationFailureContext.killNode(ClusterNode node) |
Modifier and Type | Method and Description |
---|---|
CacheConfiguration<K,V> |
CacheConfiguration.setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter)
Sets filter which determines on what nodes the cache should be started.
|
CollectionConfiguration |
CollectionConfiguration.setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter) |
boolean |
TopologyValidator.validate(Collection<ClusterNode> nodes)
Validates topology.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
CacheRebalancingEvent.discoveryNode()
Gets shadow of the node that triggered this rebalancing event.
|
ClusterNode |
DiscoveryEvent.eventNode()
Gets node that caused this event to be generated.
|
ClusterNode |
CacheEvent.eventNode()
Gets node which initiated cache operation or
null if that node is not available. |
ClusterNode |
EventAdapter.node()
Node where event occurred and was recorded
|
ClusterNode |
Event.node()
Node where event occurred and was recorded
|
ClusterNode |
JobEvent.taskNode()
Get node where parent task of the job has originated.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
DiscoveryEvent.topologyNodes()
Gets topology nodes from topology snapshot.
|
Modifier and Type | Method and Description |
---|---|
void |
DiscoveryEvent.eventNode(ClusterNode evtNode)
Sets node this event is referring to.
|
void |
EventAdapter.node(ClusterNode node)
Sets node where even is occurred (i.e. node local to the event).
|
void |
JobEvent.taskNode(ClusterNode taskNode)
Sets node where parent task of the job has originated.
|
Modifier and Type | Method and Description |
---|---|
void |
DiscoveryEvent.topologySnapshot(long topVer,
Collection<ClusterNode> topSnapshot)
Sets the topology snapshot.
|
Constructor and Description |
---|
CacheEvent(String cacheName,
ClusterNode node,
@Nullable ClusterNode evtNode,
String msg,
int type,
int part,
boolean near,
Object key,
IgniteUuid xid,
Object lockId,
Object newVal,
boolean hasNewVal,
Object oldVal,
boolean hasOldVal,
UUID subjId,
String cloClsName,
String taskName)
Constructs cache event.
|
CacheEvent(String cacheName,
ClusterNode node,
@Nullable ClusterNode evtNode,
String msg,
int type,
int part,
boolean near,
Object key,
IgniteUuid xid,
Object lockId,
Object newVal,
boolean hasNewVal,
Object oldVal,
boolean hasOldVal,
UUID subjId,
String cloClsName,
String taskName)
Constructs cache event.
|
CacheQueryExecutedEvent(ClusterNode node,
String msg,
int type,
String qryType,
@Nullable String cacheName,
@Nullable String clsName,
@Nullable String clause,
@Nullable IgniteBiPredicate<K,V> scanQryFilter,
@Nullable CacheEntryEventSerializableFilter<K,V> contQryFilter,
@Nullable Object[] args,
@Nullable UUID subjId,
@Nullable String taskName) |
CacheQueryReadEvent(ClusterNode node,
String msg,
int type,
String qryType,
@Nullable String cacheName,
@Nullable String clsName,
@Nullable String clause,
@Nullable IgniteBiPredicate<K,V> scanQryFilter,
@Nullable CacheEntryEventSerializableFilter<K,V> contQryFilter,
@Nullable Object[] args,
@Nullable UUID subjId,
@Nullable String taskName,
K key,
V val,
V oldVal,
@Nullable Object row) |
CacheRebalancingEvent(String cacheName,
ClusterNode node,
String msg,
int type,
int part,
ClusterNode discoNode,
int discoEvtType,
long discoTs)
Constructs cache event.
|
CheckpointEvent(ClusterNode node,
String msg,
int type,
String cpKey)
Creates new checkpoint event with given parameters.
|
DeploymentEvent(ClusterNode node,
String msg,
int type)
Creates deployment event with given parameters.
|
DiscoveryEvent(ClusterNode node,
String msg,
int type,
ClusterNode evtNode)
Creates new discovery event with given parameters.
|
EventAdapter(ClusterNode node,
String msg,
int type)
Creates event based with given parameters.
|
IgfsEvent(IgfsPath path,
ClusterNode node,
int type)
Constructs an event instance.
|
IgfsEvent(IgfsPath path,
ClusterNode node,
int type,
long dataSize)
Constructs an event instance for close events:
(
EventType.EVT_IGFS_FILE_CLOSED_READ ,
EventType.EVT_IGFS_FILE_CLOSED_WRITE ). |
IgfsEvent(IgfsPath path,
ClusterNode node,
int type,
Map<String,String> meta)
Constructs an event instance for file metadata update events
(
EventType.EVT_IGFS_META_UPDATED ). |
IgfsEvent(IgfsPath path,
IgfsPath newPath,
ClusterNode node,
int type)
Constructs an event instance for path modification event
(
EventType.EVT_IGFS_FILE_RENAMED ,
EventType.EVT_IGFS_DIR_RENAMED ). |
JobEvent(ClusterNode node,
String msg,
int type)
Creates job event with given parameters.
|
TaskEvent(ClusterNode node,
String msg,
int type,
IgniteUuid sesId,
String taskName,
String taskClsName,
boolean internal,
@Nullable UUID subjId)
Creates task event with given parameters.
|
TransactionStateChangedEvent(ClusterNode node,
String msg,
int type,
Transaction tx) |
WalSegmentArchivedEvent(@NotNull ClusterNode node,
long absWalSegmentIdx,
File archiveFile)
Creates WAL segment event
|
WalSegmentArchivedEvent(@NotNull ClusterNode node,
long absWalSegmentIdx,
File archiveFile,
int evtType) |
WalSegmentCompactedEvent(@NotNull ClusterNode node,
long absWalSegmentIdx,
File archiveFile)
Creates WAL segment compaction event.
|
Modifier and Type | Method and Description |
---|---|
HadoopMapReducePlan |
HadoopMapReducePlanner.preparePlan(HadoopJob job,
Collection<ClusterNode> top,
@Nullable HadoopMapReducePlan oldPlan)
Prepares map-reduce execution plan for the given job and topology.
|
Modifier and Type | Method and Description |
---|---|
HadoopMapReducePlan |
IgniteHadoopWeightedMapReducePlanner.preparePlan(HadoopJob job,
Collection<ClusterNode> nodes,
@Nullable HadoopMapReducePlan oldPlan)
Prepares map-reduce execution plan for the given job and topology.
|
Modifier and Type | Method and Description |
---|---|
protected static Map<String,Collection<UUID>> |
HadoopAbstractMapReducePlanner.groupByHost(Collection<ClusterNode> top)
Groups nodes by host names.
|
HadoopMapReducePlan |
HadoopTestRoundRobinMrPlanner.preparePlan(HadoopJob job,
Collection<ClusterNode> top,
@Nullable HadoopMapReducePlan oldPlan)
Prepares map-reduce execution plan for the given job and topology.
|
protected static org.apache.ignite.internal.processors.hadoop.planner.HadoopMapReducePlanTopology |
HadoopAbstractMapReducePlanner.topology(Collection<ClusterNode> nodes)
Create plan topology.
|
Modifier and Type | Method and Description |
---|---|
@Nullable Map<? extends ComputeJob,ClusterNode> |
IgfsTask.map(List<ClusterNode> subgrid,
@Nullable IgfsTaskArgs<T> args)
This method is called to map or split grid task into multiple grid jobs.
|
Modifier and Type | Method and Description |
---|---|
List<List<ClusterNode>> |
DatasetAffinityFunctionWrapper.assignPartitions(AffinityFunctionContext affCtx)
Gets affinity nodes for a partition.
|
Modifier and Type | Method and Description |
---|---|
Map |
CrossOverTask.map(List<ClusterNode> nodes,
List<Long> chromosomeKeys)
Map Jobs to nodes using data affinity.
|
Map |
TruncateSelectionTask.map(List<ClusterNode> nodes,
List<Long> chromosomeKeys) |
Map |
FitnessTask.map(List<ClusterNode> nodes,
List<Long> chromosomeKeys) |
Map |
MutateTask.map(List<ClusterNode> nodes,
List<Long> chromosomeKeys) |
Modifier and Type | Method and Description |
---|---|
List<List<ClusterNode>> |
PlatformDotNetAffinityFunction.assignPartitions(AffinityFunctionContext affCtx)
Gets affinity nodes for a partition.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
PluginContext.localNode()
Gets local grid node.
|
ClusterNode |
CachePluginContext.localNode()
Gets local grid node.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
PluginContext.nodes()
Gets a collection of all grid nodes.
|
Modifier and Type | Method and Description |
---|---|
void |
PluginProvider.validateNewNode(ClusterNode node)
Validates that new node can join grid topology, this method is called on coordinator
node before new node joins topology.
|
void |
CachePluginProvider.validateRemote(CacheConfiguration locCfg,
CacheConfiguration rmtCfg,
ClusterNode rmtNode)
Checks that remote caches has configuration compatible with the local.
|
Modifier and Type | Field and Description |
---|---|
protected IgnitePredicate<ClusterNode> |
ServiceConfiguration.nodeFilter
Node filter.
|
Modifier and Type | Method and Description |
---|---|
IgnitePredicate<ClusterNode> |
ServiceConfiguration.getNodeFilter()
Gets node filter used to filter nodes on which the service will be deployed.
|
Modifier and Type | Method and Description |
---|---|
ServiceConfiguration |
ServiceConfiguration.setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter)
Sets node filter used to filter nodes on which the service will be deployed.
|
Modifier and Type | Method and Description |
---|---|
protected ClusterNode |
IgniteSpiAdapter.getLocalNode() |
ClusterNode |
IgniteSpiContext.localNode()
Gets local grid node.
|
@Nullable ClusterNode |
IgniteSpiContext.node(UUID nodeId)
Gets a node instance based on its ID.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
IgniteSpiContext.nodes()
Gets a collection of all grid nodes.
|
Collection<ClusterNode> |
IgniteSpiContext.remoteDaemonNodes()
Gets a collection of all remote daemon nodes in topology.
|
Collection<ClusterNode> |
IgniteSpiContext.remoteNodes()
Gets a collection of remote grid nodes.
|
Modifier and Type | Method and Description |
---|---|
protected void |
IgniteSpiAdapter.checkConfigurationConsistency0(IgniteSpiContext spiCtx,
ClusterNode node,
boolean starting)
Method which is called in the end of checkConfigurationConsistency() method.
|
void |
IgniteSpiContext.resolveCommunicationFailure(ClusterNode node,
Exception err) |
void |
IgniteSpiContext.send(ClusterNode node,
Serializable msg,
String topic)
Sends a message to a remote node.
|
@Nullable IgniteNodeValidationResult |
IgniteSpiContext.validateNode(ClusterNode node)
Validates that new node can join grid topology, this method is called on coordinator
node before new node joins topology.
|
@Nullable IgniteNodeValidationResult |
IgniteSpiContext.validateNode(ClusterNode node,
DiscoveryDataBag discoData) |
Modifier and Type | Method and Description |
---|---|
void |
CommunicationSpi.sendMessage(ClusterNode destNode,
T msg)
Sends given message to destination node.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TcpCommunicationSpi.checkConfigurationConsistency0(IgniteSpiContext spiCtx,
ClusterNode node,
boolean starting)
Method which is called in the end of checkConfigurationConsistency() method.
|
protected org.apache.ignite.internal.util.nio.GridCommunicationClient |
TcpCommunicationSpi.createTcpClient(ClusterNode node,
int connIdx)
Establish TCP connection to remote node and returns client.
|
Collection<InetSocketAddress> |
TcpCommunicationSpi.nodeAddresses(ClusterNode node,
boolean filterReachableAddresses) |
protected void |
TcpCommunicationSpi.processClientCreationError(ClusterNode node,
Collection<InetSocketAddress> addrs,
IgniteCheckedException errs)
Process errors if TCP client to remote node hasn't been created.
|
void |
TcpCommunicationSpi.sendMessage(ClusterNode node,
Message msg)
Sends given message to destination node.
|
void |
TcpCommunicationSpi.sendMessage(ClusterNode node,
Message msg,
IgniteInClosure<IgniteException> ackC)
Sends given message to destination node.
|
Modifier and Type | Method and Description |
---|---|
IgniteFuture<BitSet> |
TcpCommunicationSpi.checkConnection(List<ClusterNode> nodes) |
Modifier and Type | Method and Description |
---|---|
ClusterNode |
DiscoverySpi.getLocalNode()
Gets local node.
|
@Nullable ClusterNode |
DiscoverySpi.getNode(UUID nodeId)
Gets node by ID.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
DiscoverySpi.getRemoteNodes()
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
|
Modifier and Type | Method and Description |
---|---|
org.apache.ignite.internal.processors.security.SecurityContext |
DiscoverySpiNodeAuthenticator.authenticateNode(ClusterNode node,
SecurityCredentials cred)
Security credentials.
|
IgniteFuture<?> |
DiscoverySpiListener.onDiscovery(int type,
long topVer,
ClusterNode node,
Collection<ClusterNode> topSnapshot,
@Nullable Map<Long,Collection<ClusterNode>> topHist,
@Nullable DiscoverySpiCustomMessage data)
Notification for grid node discovery events.
|
void |
DiscoverySpiListener.onLocalNodeInitialized(ClusterNode locNode)
Notification of local node initialization.
|
Modifier and Type | Method and Description |
---|---|
IgniteFuture<?> |
DiscoverySpiListener.onDiscovery(int type,
long topVer,
ClusterNode node,
Collection<ClusterNode> topSnapshot,
@Nullable Map<Long,Collection<ClusterNode>> topHist,
@Nullable DiscoverySpiCustomMessage data)
Notification for grid node discovery events.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
TcpDiscoverySpi.getLocalNode()
Gets local node.
|
@Nullable ClusterNode |
TcpDiscoverySpi.getNode(UUID nodeId)
Gets node by ID.
|
ClusterNode |
TcpDiscoverySpi.getNode0(UUID id) |
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
TcpDiscoverySpi.getRemoteNodes()
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoverySpi.resolveCommunicationFailure(ClusterNode node,
Exception err) |
protected void |
TcpDiscoverySpi.writeToSocket(ClusterNode node,
Socket sock,
OutputStream out,
org.apache.ignite.spi.discovery.tcp.messages.TcpDiscoveryAbstractMessage msg,
long timeout) |
Modifier and Type | Method and Description |
---|---|
ClusterNode |
ZookeeperDiscoverySpi.getLocalNode()
Gets local node.
|
@Nullable ClusterNode |
ZookeeperDiscoverySpi.getNode(UUID nodeId)
Gets node by ID.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
ZookeeperDiscoverySpi.getRemoteNodes()
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
|
Modifier and Type | Method and Description |
---|---|
void |
ZookeeperDiscoverySpi.resolveCommunicationFailure(ClusterNode node,
Exception err) |
Modifier and Type | Method and Description |
---|---|
ClusterNode |
FailoverSpi.failover(FailoverContext ctx,
List<ClusterNode> top)
This method is called when method
ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns
value ComputeJobResultPolicy.FAILOVER policy indicating that the result of
job execution must be failed over. |
ClusterNode |
FailoverContext.getBalancedNode(List<ClusterNode> top)
Gets the next balanced node for failed job.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
FailoverSpi.failover(FailoverContext ctx,
List<ClusterNode> top)
This method is called when method
ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns
value ComputeJobResultPolicy.FAILOVER policy indicating that the result of
job execution must be failed over. |
ClusterNode |
FailoverContext.getBalancedNode(List<ClusterNode> top)
Gets the next balanced node for failed job.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
AlwaysFailoverSpi.failover(FailoverContext ctx,
List<ClusterNode> top)
This method is called when method
ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns
value ComputeJobResultPolicy.FAILOVER policy indicating that the result of
job execution must be failed over. |
Modifier and Type | Method and Description |
---|---|
ClusterNode |
AlwaysFailoverSpi.failover(FailoverContext ctx,
List<ClusterNode> top)
This method is called when method
ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns
value ComputeJobResultPolicy.FAILOVER policy indicating that the result of
job execution must be failed over. |
Modifier and Type | Method and Description |
---|---|
ClusterNode |
JobStealingFailoverSpi.failover(FailoverContext ctx,
List<ClusterNode> top)
This method is called when method
ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns
value ComputeJobResultPolicy.FAILOVER policy indicating that the result of
job execution must be failed over. |
Modifier and Type | Method and Description |
---|---|
ClusterNode |
JobStealingFailoverSpi.failover(FailoverContext ctx,
List<ClusterNode> top)
This method is called when method
ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns
value ComputeJobResultPolicy.FAILOVER policy indicating that the result of
job execution must be failed over. |
Modifier and Type | Method and Description |
---|---|
ClusterNode |
NeverFailoverSpi.failover(FailoverContext ctx,
List<ClusterNode> top)
This method is called when method
ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns
value ComputeJobResultPolicy.FAILOVER policy indicating that the result of
job execution must be failed over. |
Modifier and Type | Method and Description |
---|---|
ClusterNode |
NeverFailoverSpi.failover(FailoverContext ctx,
List<ClusterNode> top)
This method is called when method
ComputeTask.result(org.apache.ignite.compute.ComputeJobResult, List) returns
value ComputeJobResultPolicy.FAILOVER policy indicating that the result of
job execution must be failed over. |
Constructor and Description |
---|
IndexingQueryCacheFilter(org.apache.ignite.internal.processors.cache.GridCacheAffinityManager aff,
Set<Integer> parts,
org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion topVer,
ClusterNode locNode)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
LoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
LoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
AdaptiveLoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Modifier and Type | Method and Description |
---|---|
double |
AdaptiveCpuLoadProbe.getLoad(ClusterNode node,
int jobsSentSinceLastUpdate)
Calculates load value for a given node.
|
double |
AdaptiveProcessingTimeLoadProbe.getLoad(ClusterNode node,
int jobsSentSinceLastUpdate)
Calculates load value for a given node.
|
double |
AdaptiveLoadProbe.getLoad(ClusterNode node,
int jobsSentSinceLastUpdate)
Calculates load value for a given node.
|
double |
AdaptiveJobCountLoadProbe.getLoad(ClusterNode node,
int jobsSentSinceLastUpdate)
Calculates load value for a given node.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
AdaptiveLoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
RoundRobinLoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
RoundRobinLoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
WeightedRandomLoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
WeightedRandomLoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Follow @ApacheIgnite
Ignite Database and Caching Platform : ver. 2.7.2 Release Date : February 6 2019