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.consistenthash |
Contains consistent hash based cache affinity for partitioned cache.
|
org.apache.ignite.cache.affinity.fair |
Contains fair cache affinity for partitioned cache.
|
org.apache.ignite.cache.affinity.rendezvous |
Contains HRW-based cache affinity for partitioned cache.
|
org.apache.ignite.cluster | |
org.apache.ignite.compute |
Contains Compute Grid functionality.
|
org.apache.ignite.compute.gridify.aop |
Contains common classes for different AOP providers.
|
org.apache.ignite.events |
Contains Event Subscription functionality together with various events emitted by Ignite.
|
org.apache.ignite.igfs.mapreduce |
Contains APIs for In-Memory MapReduce over IGFS.
|
org.apache.ignite.plugin | |
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.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.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.
|
org.apache.ignite.streamer |
Contains main Streaming APIs.
|
org.apache.ignite.streamer.router |
Contains streamer event router implementations.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
IgniteCluster.localNode()
Gets local grid node.
|
<K> ClusterNode |
IgniteCluster.mapKeyToNode(String cacheName,
K key)
This method provides ability to detect which cache keys are mapped to which nodes
on cache instance with given name.
|
Modifier and Type | Method and Description |
---|---|
<K> Map<ClusterNode,Collection<K>> |
IgniteCluster.mapKeysToNodes(String cacheName,
Collection<? extends K> keys)
This method provides ability to detect which cache keys are mapped to which nodes
on cache instance with given name.
|
Collection<ClusterNode> |
IgniteCluster.topology(long topVer)
Gets a topology by version.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
CacheAffinity.mapKeyToNode(K key)
This method provides ability to detect to which primary node the given key
is mapped.
|
ClusterNode |
CacheAffinity.mapPartitionToNode(int part)
Gets primary node for the given partition.
|
Modifier and Type | Method and Description |
---|---|
List<List<ClusterNode>> |
CacheAffinityFunction.assignPartitions(CacheAffinityFunctionContext affCtx)
Gets affinity nodes for a partition.
|
List<ClusterNode> |
CacheAffinityFunctionContext.currentTopologySnapshot()
Gets current topology snapshot.
|
Map<ClusterNode,Collection<K>> |
CacheAffinity.mapKeysToNodes(Collection<? extends K> keys)
This method provides ability to detect which keys are mapped to which nodes.
|
Collection<ClusterNode> |
CacheAffinity.mapKeyToPrimaryAndBackups(K key)
Gets primary and backup nodes for the key.
|
Map<Integer,ClusterNode> |
CacheAffinity.mapPartitionsToNodes(Collection<Integer> parts)
Gets primary nodes for the given partitions.
|
Collection<ClusterNode> |
CacheAffinity.mapPartitionToPrimaryAndBackups(int part)
Gets primary and backup nodes for partition.
|
List<ClusterNode> |
CacheAffinityFunctionContext.previousAssignment(int part)
Gets affinity assignment for given partition on previous topology version.
|
Modifier and Type | Method and Description |
---|---|
int[] |
CacheAffinity.allPartitions(ClusterNode n)
Gets partition ids for which nodes of the given projection has ownership
(either primary or backup).
|
int[] |
CacheAffinity.backupPartitions(ClusterNode n)
Gets partition ids for which nodes of the given projection has backup
ownership.
|
boolean |
CacheAffinity.isBackup(ClusterNode n,
K key)
Returns
true if local node is one of the backup nodes for given key. |
boolean |
CacheAffinity.isPrimary(ClusterNode n,
K key)
Returns
true if given node is the primary node for given key. |
boolean |
CacheAffinity.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
"CacheAffinity.isPrimary(org.apache.ignite.cluster.ClusterNode, Object) ||
CacheAffinity.isBackup(org.apache.ignite.cluster.ClusterNode, Object) )",
however it is more efficient as it makes both checks at once. |
int[] |
CacheAffinity.primaryPartitions(ClusterNode n)
Gets partition ids for which nodes of the given projection has primary
ownership.
|
Object |
CacheAffinityNodeHashResolver.resolve(ClusterNode node)
Resolve alternate hash value for the given Grid node.
|
Object |
CacheAffinityNodeAddressHashResolver.resolve(ClusterNode node)
Resolve alternate hash value for the given Grid node.
|
Object |
CacheAffinityNodeIdHashResolver.resolve(ClusterNode node)
Resolve alternate hash value for the given Grid node.
|
Modifier and Type | Method and Description |
---|---|
List<List<ClusterNode>> |
CacheConsistentHashAffinityFunction.assignPartitions(CacheAffinityFunctionContext ctx)
Gets affinity nodes for a partition.
|
IgniteBiPredicate<ClusterNode,ClusterNode> |
CacheConsistentHashAffinityFunction.getBackupFilter()
Gets optional backup filter.
|
IgniteBiPredicate<ClusterNode,ClusterNode> |
CacheConsistentHashAffinityFunction.getBackupFilter()
Gets optional backup filter.
|
Collection<ClusterNode> |
CacheConsistentHashAffinityFunction.nodes(int part,
Collection<ClusterNode> nodes,
int backups)
Assigns nodes to one partition.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
CacheConsistentHashAffinityFunction.nodes(int part,
Collection<ClusterNode> nodes,
int backups)
Assigns nodes to one partition.
|
void |
CacheConsistentHashAffinityFunction.setBackupFilter(IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter)
Sets optional backup filter.
|
void |
CacheConsistentHashAffinityFunction.setBackupFilter(IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter)
Sets optional backup filter.
|
Constructor and Description |
---|
CacheConsistentHashAffinityFunction(int parts,
IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter)
Initializes optional counts for replicas and backups.
|
CacheConsistentHashAffinityFunction(int parts,
IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter)
Initializes optional counts for replicas and backups.
|
Modifier and Type | Method and Description |
---|---|
List<List<ClusterNode>> |
CachePartitionFairAffinity.assignPartitions(CacheAffinityFunctionContext ctx)
Gets affinity nodes for a partition.
|
Modifier and Type | Method and Description |
---|---|
List<ClusterNode> |
CacheRendezvousAffinityFunction.assignPartition(int part,
List<ClusterNode> nodes,
int backups,
Map<UUID,Collection<ClusterNode>> neighborhoodCache)
Returns collection of nodes (primary first) for specified partition.
|
List<List<ClusterNode>> |
CacheRendezvousAffinityFunction.assignPartitions(CacheAffinityFunctionContext affCtx)
Gets affinity nodes for a partition.
|
IgniteBiPredicate<ClusterNode,ClusterNode> |
CacheRendezvousAffinityFunction.getBackupFilter()
Gets optional backup filter.
|
IgniteBiPredicate<ClusterNode,ClusterNode> |
CacheRendezvousAffinityFunction.getBackupFilter()
Gets optional backup filter.
|
Modifier and Type | Method and Description |
---|---|
List<ClusterNode> |
CacheRendezvousAffinityFunction.assignPartition(int part,
List<ClusterNode> nodes,
int backups,
Map<UUID,Collection<ClusterNode>> neighborhoodCache)
Returns collection of nodes (primary first) for specified partition.
|
List<ClusterNode> |
CacheRendezvousAffinityFunction.assignPartition(int part,
List<ClusterNode> nodes,
int backups,
Map<UUID,Collection<ClusterNode>> neighborhoodCache)
Returns collection of nodes (primary first) for specified partition.
|
void |
CacheRendezvousAffinityFunction.setBackupFilter(IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter)
Sets optional backup filter.
|
void |
CacheRendezvousAffinityFunction.setBackupFilter(IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter)
Sets optional backup filter.
|
Constructor and Description |
---|
CacheRendezvousAffinityFunction(int parts,
IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter)
Initializes optional counts for replicas and backups.
|
CacheRendezvousAffinityFunction(int parts,
IgniteBiPredicate<ClusterNode,ClusterNode> backupFilter)
Initializes optional counts for replicas and backups.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
ClusterGroup.node()
Gets first node from the list of nodes in this projection.
|
ClusterNode |
ClusterGroup.node(UUID nid)
Gets a node for given ID from this grid projection.
|
Modifier and Type | Method and Description |
---|---|
Collection<ClusterNode> |
ClusterGroup.nodes()
Gets read-only collections of nodes in this projection.
|
IgnitePredicate<ClusterNode> |
ClusterGroup.predicate()
Gets predicate that defines a subset of nodes for this projection.
|
Modifier and Type | Method and Description |
---|---|
ClusterGroup |
ClusterGroup.forHost(ClusterNode node)
Gets grid projection consisting from the nodes in this projection residing on the
same host as given node.
|
ClusterGroup |
ClusterGroup.forNode(ClusterNode node,
ClusterNode... nodes)
Creates a grid projection for the given node.
|
ClusterGroup |
ClusterGroup.forNode(ClusterNode node,
ClusterNode... nodes)
Creates a grid projection for the given node.
|
ClusterGroup |
ClusterGroup.forOthers(ClusterNode node,
ClusterNode... nodes)
Creates a grid projection for nodes other than given nodes.
|
ClusterGroup |
ClusterGroup.forOthers(ClusterNode node,
ClusterNode... nodes)
Creates a grid projection for nodes other than given nodes.
|
Modifier and Type | Method and Description |
---|---|
ClusterGroup |
ClusterGroup.forNodes(Collection<? extends ClusterNode> nodes)
Creates a grid projection over a given set of nodes.
|
ClusterGroup |
ClusterGroup.forPredicate(IgnitePredicate<ClusterNode> p)
Creates a grid projection which includes all nodes that pass the given predicate filter.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
ComputeLoadBalancer.getBalancedNode(ComputeJob job,
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> |
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.
|
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 |
---|---|
ClusterNode |
ComputeLoadBalancer.getBalancedNode(ComputeJob job,
Collection<ClusterNode> exclNodes)
Gets the next balanced node according to the underlying load balancing policy.
|
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 | Method and Description |
---|---|
ClusterNode |
CachePreloadingEvent.discoveryNode()
Gets shadow of the node that triggered this preloading event.
|
ClusterNode |
CacheEvent.eventNode()
Gets node which initiated cache operation or
null if that node is not available. |
ClusterNode |
DiscoveryEvent.eventNode()
Gets node that caused this event to be generated.
|
ClusterNode |
Event.node()
Node where event occurred and was recorded
|
ClusterNode |
EventAdapter.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,
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.
|
CachePreloadingEvent(String cacheName,
ClusterNode node,
String msg,
int type,
int part,
ClusterNode discoNode,
int discoEvtType,
long discoTs)
Constructs cache event.
|
CacheQueryExecutedEvent(ClusterNode node,
String msg,
int type,
org.apache.ignite.internal.processors.cache.query.CacheQueryType qryType,
String cacheName,
String clsName,
String clause,
IgniteBiPredicate<K,V> scanQryFilter,
javax.cache.event.CacheEntryEventFilter<K,V> contQryFilter,
Object[] args,
UUID subjId,
String taskName) |
CacheQueryReadEvent(ClusterNode node,
String msg,
int type,
org.apache.ignite.internal.processors.cache.query.CacheQueryType qryType,
String cacheName,
String clsName,
String clause,
IgniteBiPredicate<K,V> scanQryFilter,
javax.cache.event.CacheEntryEventFilter<K,V> contQryFilter,
Object[] args,
UUID subjId,
String taskName,
K key,
V val,
V oldVal,
Object row) |
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.
|
SwapSpaceEvent(ClusterNode node,
String msg,
int type,
String space)
Creates swap space event.
|
TaskEvent(ClusterNode node,
String msg,
int type,
IgniteUuid sesId,
String taskName,
String taskClsName,
boolean internal,
UUID subjId)
Creates task event with given parameters.
|
Modifier and Type | Method and Description |
---|---|
Map<? extends ComputeJob,ClusterNode> |
IgfsTask.map(List<ClusterNode> subgrid,
IgfsTaskArgs<T> args)
This method is called to map or split grid task into multiple grid jobs.
|
Modifier and Type | Method and Description |
---|---|
Map<? extends ComputeJob,ClusterNode> |
IgfsTask.map(List<ClusterNode> subgrid,
IgfsTaskArgs<T> args)
This method is called to map or split grid task into multiple grid jobs.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
PluginContext.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.
|
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 |
---|---|
void |
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 |
---|---|
ClusterNode |
IgniteSpiContext.localNode()
Gets local grid node.
|
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.send(ClusterNode node,
Serializable msg,
String topic)
Sends a message to a remote node.
|
IgniteSpiNodeValidationResult |
IgniteSpiContext.validateNode(ClusterNode node)
Validates that new node can join grid topology, this method is called on coordinator
node before new node joins topology.
|
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.createNioClient(ClusterNode node) |
protected org.apache.ignite.internal.util.nio.GridCommunicationClient |
TcpCommunicationSpi.createShmemClient(ClusterNode node,
Integer port) |
protected org.apache.ignite.internal.util.nio.GridCommunicationClient |
TcpCommunicationSpi.createTcpClient(ClusterNode node)
Establish TCP connection to remote node and returns client.
|
void |
TcpCommunicationSpi.sendMessage(ClusterNode node,
MessageAdapter msg)
Sends given message to destination node.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
DiscoverySpi.getLocalNode()
Gets local node.
|
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.GridSecurityContext |
DiscoverySpiNodeAuthenticator.authenticateNode(ClusterNode node,
GridSecurityCredentials cred)
Security credentials.
|
void |
DiscoverySpiListener.onDiscovery(int type,
long topVer,
ClusterNode node,
Collection<ClusterNode> topSnapshot,
Map<Long,Collection<ClusterNode>> topHist)
Notification for grid node discovery events.
|
Modifier and Type | Method and Description |
---|---|
void |
DiscoverySpiListener.onDiscovery(int type,
long topVer,
ClusterNode node,
Collection<ClusterNode> topSnapshot,
Map<Long,Collection<ClusterNode>> topHist)
Notification for grid node discovery events.
|
void |
DiscoverySpiListener.onDiscovery(int type,
long topVer,
ClusterNode node,
Collection<ClusterNode> topSnapshot,
Map<Long,Collection<ClusterNode>> topHist)
Notification for grid node discovery events.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
TcpDiscoverySpi.getNode(UUID nodeId)
Gets node by ID.
|
ClusterNode |
TcpClientDiscoverySpi.getNode(UUID nodeId)
Gets node by 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.
|
Collection<ClusterNode> |
TcpClientDiscoverySpi.getRemoteNodes()
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
|
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. |
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 |
AdaptiveLoadProbe.getLoad(ClusterNode node,
int jobsSentSinceLastUpdate)
Calculates load value for a given node.
|
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 |
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.
|
Modifier and Type | Method and Description |
---|---|
<T> ClusterNode |
StreamerEventRouter.route(StreamerContext ctx,
String stageName,
T evt)
Selects a node for given event that should be processed by a stage with given name.
|
Modifier and Type | Method and Description |
---|---|
<T> Map<ClusterNode,Collection<T>> |
StreamerEventRouterAdapter.route(StreamerContext ctx,
String stageName,
Collection<T> evts)
Selects a node for given events that should be processed by a stage with given name.
|
<T> Map<ClusterNode,Collection<T>> |
StreamerEventRouter.route(StreamerContext ctx,
String stageName,
Collection<T> evts)
Selects a node for given events that should be processed by a stage with given name.
|
Modifier and Type | Method and Description |
---|---|
void |
StreamerContext.broadcast(IgniteInClosure<StreamerContext> clo,
Collection<ClusterNode> nodes)
Queries streamer nodes deployed within grid.
|
<R> Collection<R> |
StreamerContext.query(IgniteClosure<StreamerContext,R> clo,
Collection<ClusterNode> nodes)
Queries streamer nodes deployed within grid.
|
<R1,R2> R2 |
StreamerContext.reduce(IgniteClosure<StreamerContext,R1> clo,
IgniteReducer<R1,R2> rdc,
Collection<ClusterNode> nodes)
Queries streamer nodes deployed within grid.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
StreamerRandomEventRouter.route(StreamerContext ctx,
String stageName,
Object evt)
Selects a node for given event that should be processed by a stage with given name.
|
ClusterNode |
StreamerRoundRobinEventRouter.route(StreamerContext ctx,
String stageName,
Object evt)
Selects a node for given event that should be processed by a stage with given name.
|
<T> ClusterNode |
StreamerCacheAffinityEventRouter.route(StreamerContext ctx,
String stageName,
T evt)
Selects a node for given event that should be processed by a stage with given name.
|
<T> ClusterNode |
StreamerAffinityEventRouter.route(StreamerContext ctx,
String stageName,
T evt)
Selects a node for given event that should be processed by a stage with given name.
|
<T> ClusterNode |
StreamerLocalEventRouter.route(StreamerContext ctx,
String stageName,
T evt)
Selects a node for given event that should be processed by a stage with given name.
|
Modifier and Type | Method and Description |
---|---|
<T> Map<ClusterNode,Collection<T>> |
StreamerLocalEventRouter.route(StreamerContext ctx,
String stageName,
Collection<T> evts)
Selects a node for given events that should be processed by a stage with given name.
|
Constructor and Description |
---|
StreamerRandomEventRouter(Collection<IgnitePredicate<ClusterNode>> predicates)
Constructs random event router with optional set of filters to apply to streamer projection.
|
Follow @ApacheIgnite
Apache Ignite Fabric : ver. 1.0.0-RC1 Release Date : February 16 2015