Package | Description |
---|---|
org.apache.ignite.spi |
Contains common classes and interfaces for SPI implementations.
|
org.apache.ignite.spi.checkpoint.cache |
Contains cache-based implementation for checkpoint SPI.
|
org.apache.ignite.spi.checkpoint.jdbc |
Contains JDBC implementation for checkpoint SPI.
|
org.apache.ignite.spi.checkpoint.s3 |
Contains S3-based implementation for checkpoint SPI.
|
org.apache.ignite.spi.checkpoint.sharedfs |
Contains shared file system implementation for checkpoint SPI.
|
org.apache.ignite.spi.collision.fifoqueue |
Contains FIFO based collision SPI implementation.
|
org.apache.ignite.spi.collision.jobstealing |
Contains job stealing collision SPI implementation.
|
org.apache.ignite.spi.collision.priorityqueue |
Contains priority based collision SPI implementation.
|
org.apache.ignite.spi.communication.tcp |
Contains default TCP/IP-based implementation for communication SPI.
|
org.apache.ignite.spi.deployment.uri |
Contains URI-based deployment SPI implementation.
|
org.apache.ignite.spi.discovery.tcp |
Contains default TCP/IP implementation for discovery SPI.
|
org.apache.ignite.spi.discovery.tcp.ipfinder |
Contains IP finder interface and adapter.
|
org.apache.ignite.spi.discovery.tcp.ipfinder.cloud |
Contains Apache jclouds based IP finder.
|
org.apache.ignite.spi.discovery.tcp.ipfinder.elb |
Contains AWS ELB-based IP finder.
|
org.apache.ignite.spi.discovery.tcp.ipfinder.gce |
Contains Google Cloud Storage IP finder.
|
org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc |
Contains JDBC IP finder implementation.
|
org.apache.ignite.spi.discovery.tcp.ipfinder.multicast |
Contains multicast-based IP finder.
|
org.apache.ignite.spi.discovery.tcp.ipfinder.s3 |
Contains AWS S3-based IP finder.
|
org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs |
Contains shared filesystem-based IP finder.
|
org.apache.ignite.spi.discovery.tcp.ipfinder.vm |
Contains local JVM-based IP finder.
|
org.apache.ignite.spi.discovery.zk |
Contains Zookeeper Discovery Spi classes and interfaces.
|
org.apache.ignite.spi.eventstorage.memory |
Contains default in-memory implementation for event storage 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.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 |
---|---|
IgniteSpiAdapter |
IgniteSpiAdapter.setName(String name)
Sets SPI name.
|
Modifier and Type | Method and Description |
---|---|
CacheCheckpointSpi |
CacheCheckpointSpi.setCacheName(String cacheName)
Sets cache name to be used by this SPI.
|
Modifier and Type | Method and Description |
---|---|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setCheckpointTableName(String tblName)
Sets checkpoint table name.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setDataSource(DataSource dataSrc)
Sets DataSource to use for database access.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setExpireDateFieldName(String expDateName)
Sets checkpoint expiration date field name.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setExpireDateFieldType(String expDateType)
Sets checkpoint expiration date field type.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setKeyFieldName(String keyName)
Sets checkpoint key field name.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setKeyFieldType(String keyType)
Sets checkpoint key field type.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setNumberOfRetries(int retryNum)
Sets number of retries in case of any database errors.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setPwd(String pwd)
Sets checkpoint database password.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setUser(String user)
Sets checkpoint database user name.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setValueFieldName(String valName)
Sets checkpoint value field name.
|
JdbcCheckpointSpi |
JdbcCheckpointSpi.setValueFieldType(String valType)
Sets checkpoint value field type.
|
Modifier and Type | Method and Description |
---|---|
S3CheckpointSpi |
S3CheckpointSpi.setAwsCredentials(com.amazonaws.auth.AWSCredentials cred)
Sets AWS credentials.
|
S3CheckpointSpi |
S3CheckpointSpi.setBucketEndpoint(String bucketEndpoint)
Sets bucket endpoint.
|
S3CheckpointSpi |
S3CheckpointSpi.setBucketNameSuffix(String bucketNameSuffix)
Sets bucket name suffix.
|
S3CheckpointSpi |
S3CheckpointSpi.setClientConfiguration(com.amazonaws.ClientConfiguration cfg)
Sets Amazon client configuration.
|
S3CheckpointSpi |
S3CheckpointSpi.setSSEAlgorithm(String sseAlg)
Sets server-side encryption algorithm for Amazon S3-managed encryption keys.
|
Modifier and Type | Method and Description |
---|---|
SharedFsCheckpointSpi |
SharedFsCheckpointSpi.setDirectoryPaths(Collection<String> dirPaths)
Sets path to a shared directory where checkpoints will be stored.
|
Modifier and Type | Method and Description |
---|---|
FifoQueueCollisionSpi |
FifoQueueCollisionSpi.setParallelJobsNumber(int parallelJobsNum)
Sets number of jobs that can be executed in parallel.
|
FifoQueueCollisionSpi |
FifoQueueCollisionSpi.setWaitingJobsNumber(int waitJobsNum)
Sets maximum number of jobs that are allowed to wait in waiting queue.
|
Modifier and Type | Method and Description |
---|---|
JobStealingCollisionSpi |
JobStealingCollisionSpi.setActiveJobsThreshold(int activeJobsThreshold)
Sets number of jobs that can be executed in parallel.
|
JobStealingCollisionSpi |
JobStealingCollisionSpi.setMaximumStealingAttempts(int maxStealingAttempts)
Gets maximum number of attempts to steal job by another node.
|
JobStealingCollisionSpi |
JobStealingCollisionSpi.setMessageExpireTime(long msgExpireTime)
Message expire time configuration parameter.
|
JobStealingCollisionSpi |
JobStealingCollisionSpi.setStealingAttributes(Map<String,? extends Serializable> stealAttrs)
Configuration parameter to enable stealing to/from only nodes that
have these attributes set (see
ClusterNode.attribute(String) and
IgniteConfiguration.getUserAttributes() methods). |
JobStealingCollisionSpi |
JobStealingCollisionSpi.setStealingEnabled(boolean isStealingEnabled)
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
|
JobStealingCollisionSpi |
JobStealingCollisionSpi.setWaitJobsThreshold(int waitJobsThreshold)
Sets job count threshold at which this node will
start stealing jobs from other nodes.
|
Modifier and Type | Method and Description |
---|---|
PriorityQueueCollisionSpi |
PriorityQueueCollisionSpi.setDefaultPriority(int priority)
Sets default priority to use if a job does not have priority attribute set.
|
PriorityQueueCollisionSpi |
PriorityQueueCollisionSpi.setJobPriorityAttributeKey(String jobPriAttrKey)
Sets job priority attribute key.
|
PriorityQueueCollisionSpi |
PriorityQueueCollisionSpi.setParallelJobsNumber(int parallelJobsNum)
Sets number of jobs that can be executed in parallel.
|
PriorityQueueCollisionSpi |
PriorityQueueCollisionSpi.setPriorityAttributeKey(String taskPriAttrKey)
Sets task priority attribute key.
|
PriorityQueueCollisionSpi |
PriorityQueueCollisionSpi.setStarvationIncrement(int starvationInc)
Sets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
|
PriorityQueueCollisionSpi |
PriorityQueueCollisionSpi.setStarvationPreventionEnabled(boolean preventStarvation)
Sets flag indicating whether job starvation prevention is enabled.
|
PriorityQueueCollisionSpi |
PriorityQueueCollisionSpi.setWaitingJobsNumber(int waitJobsNum)
Maximum number of jobs that are allowed to wait in waiting queue.
|
Modifier and Type | Method and Description |
---|---|
TcpCommunicationSpi |
TcpCommunicationSpi.setAckSendThreshold(int ackSndThreshold)
Sets number of received messages per connection to node after which acknowledgment message is sent.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setAddressResolver(AddressResolver addrRslvr)
Sets address resolver.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setConnectionsPerNode(int maxConnectionsPerNode)
Sets number of connections to each remote node. if
TcpCommunicationSpi.isUsePairedConnections()
is true then number of connections is doubled and half is used for incoming and
half for outgoing messages. |
TcpCommunicationSpi |
TcpCommunicationSpi.setConnectTimeout(long connTimeout)
Sets connect timeout used when establishing connection
with remote nodes.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setDirectBuffer(boolean directBuf)
Sets flag to allocate direct or heap buffer in SPI.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setDirectSendBuffer(boolean directSndBuf)
Sets whether to use direct buffer for sending.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setFilterReachableAddresses(boolean filterReachableAddresses)
Setting this option to
true enables filter for reachable
addresses on creating tcp client. |
TcpCommunicationSpi |
TcpCommunicationSpi.setIdleConnectionTimeout(long idleConnTimeout)
Sets maximum idle connection timeout upon which a connection
to client will be closed.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setLocalAddress(String locAddr)
Sets local host address for socket binding.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setLocalPort(int locPort)
Sets local port for socket binding.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setLocalPortRange(int locPortRange)
Sets local port range for local host ports (value must greater than or equal to 0).
|
TcpCommunicationSpi |
TcpCommunicationSpi.setMaxConnectTimeout(long maxConnTimeout)
Sets maximum connect timeout.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setMessageQueueLimit(int msgQueueLimit)
Sets message queue limit for incoming and outgoing messages.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setReconnectCount(int reconCnt)
Sets maximum number of reconnect attempts used when establishing connection
with remote nodes.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setSelectorsCount(int selectorsCnt)
Sets the count of selectors te be used in TCP server.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setSelectorSpins(long selectorSpins)
Defines how many non-blocking
selector.selectNow() should be made before
falling into selector.select(long) in NIO server. |
TcpCommunicationSpi |
TcpCommunicationSpi.setSharedMemoryPort(int shmemPort)
Sets local port to accept shared memory connections.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setSlowClientQueueLimit(int slowClientQueueLimit)
Sets slow client queue limit.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setSocketReceiveBuffer(int sockRcvBuf)
Sets receive buffer size for sockets created or accepted by this SPI.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setSocketSendBuffer(int sockSndBuf)
Sets send buffer size for sockets created or accepted by this SPI.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setSocketWriteTimeout(long sockWriteTimeout)
Sets socket write timeout for TCP connection.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setTcpNoDelay(boolean tcpNoDelay)
Sets value for
TCP_NODELAY socket option. |
TcpCommunicationSpi |
TcpCommunicationSpi.setUnacknowledgedMessagesBufferSize(int unackedMsgsBufSize)
Sets maximum number of stored unacknowledged messages per connection to node.
|
TcpCommunicationSpi |
TcpCommunicationSpi.setUsePairedConnections(boolean usePairedConnections)
Set this to
true if TcpCommunicationSpi should
maintain connection for outgoing and incoming messages separately. |
Modifier and Type | Method and Description |
---|---|
UriDeploymentSpi |
UriDeploymentSpi.setCheckMd5(boolean checkMd5)
If set to
true then SPI should exclude files with same md5s from deployment. |
UriDeploymentSpi |
UriDeploymentSpi.setEncodeUri(boolean encodeUri)
Indicates that URI must be encoded before usage.
|
UriDeploymentSpi |
UriDeploymentSpi.setScanners(org.apache.ignite.spi.deployment.uri.scanners.UriDeploymentScanner... scanners)
Sets scanners.
|
UriDeploymentSpi |
UriDeploymentSpi.setTemporaryDirectoryPath(String tmpDirPath)
Sets absolute path to temporary directory which will be used by
deployment SPI to keep all deployed classes in.
|
UriDeploymentSpi |
UriDeploymentSpi.setUriList(List<String> uriList)
Sets list of URI which point to GAR file and which should be
scanned by SPI for the new tasks.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoverySpi |
TcpDiscoverySpi.setAckTimeout(long ackTimeout)
Sets timeout for receiving acknowledgement for sent message.
|
void |
TcpDiscoverySpi.setAddressResolver(AddressResolver addrRslvr)
Sets address resolver.
|
void |
TcpDiscoverySpi.setClientReconnectDisabled(boolean clientReconnectDisabled)
Sets client reconnect disabled flag.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setForceServerMode(boolean forceSrvMode)
Deprecated.
Will be removed at 3.0.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setIpFinder(TcpDiscoveryIpFinder ipFinder)
Sets IP finder for IP addresses sharing and storing.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setIpFinderCleanFrequency(long ipFinderCleanFreq)
Sets IP finder clean frequency in milliseconds.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setJoinTimeout(long joinTimeout)
Sets join timeout.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setLocalAddress(String locAddr)
Sets local host IP address that discovery SPI uses.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setLocalPort(int locPort)
Sets local port to listen to.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setLocalPortRange(int locPortRange)
Range for local ports.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setMaxAckTimeout(long maxAckTimeout)
Sets maximum timeout for receiving acknowledgement for sent message.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setNetworkTimeout(long netTimeout)
Sets maximum network timeout to use for network operations.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setReconnectCount(int reconCnt)
Number of times node tries to (re)establish connection to another node.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setReconnectDelay(int reconDelay)
Sets the amount of time in milliseconds that node waits before retrying to (re)connect to the cluster.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setSocketTimeout(long sockTimeout)
Sets socket operations timeout.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setStatisticsPrintFrequency(long statsPrintFreq)
Sets statistics print frequency.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setThreadPriority(int threadPri)
Sets thread priority.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setTopHistorySize(int topHistSize)
Sets size of topology snapshots history.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoveryIpFinderAdapter |
TcpDiscoveryIpFinderAdapter.setShared(boolean shared)
Sets shared flag.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoveryCloudIpFinder |
TcpDiscoveryCloudIpFinder.setCredential(String credential)
Sets credential that is used during authentication on the cloud.
|
TcpDiscoveryCloudIpFinder |
TcpDiscoveryCloudIpFinder.setCredentialPath(String credentialPath)
Sets the path to a credential that is used during authentication on the cloud.
|
TcpDiscoveryCloudIpFinder |
TcpDiscoveryCloudIpFinder.setIdentity(String identity)
Sets the identity that is used as a user name during a connection to the cloud.
|
TcpDiscoveryCloudIpFinder |
TcpDiscoveryCloudIpFinder.setProvider(String provider)
Sets the cloud provider to use.
|
TcpDiscoveryCloudIpFinder |
TcpDiscoveryCloudIpFinder.setRegions(Collection<String> regions)
Sets list of regions where VMs are located.
|
TcpDiscoveryCloudIpFinder |
TcpDiscoveryCloudIpFinder.setZones(Collection<String> zones)
Sets list of zones where VMs are located.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoveryElbIpFinder.setCredentialsProvider(com.amazonaws.auth.AWSCredentialsProvider credsProvider)
Sets AWS credentials provider.
|
void |
TcpDiscoveryElbIpFinder.setLoadBalancerName(String loadBalancerName)
Sets AWS Elastic Load Balancing name which nodes are plugged under it.
|
void |
TcpDiscoveryElbIpFinder.setRegion(String region)
Sets AWS Elastic Load Balancer's region.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoveryGoogleStorageIpFinder |
TcpDiscoveryGoogleStorageIpFinder.setBucketName(String bucketName)
Sets Google Cloud Storage bucket name.
|
TcpDiscoveryGoogleStorageIpFinder |
TcpDiscoveryGoogleStorageIpFinder.setProjectName(String projectName)
Sets Google Cloud Platforms project name.
|
TcpDiscoveryGoogleStorageIpFinder |
TcpDiscoveryGoogleStorageIpFinder.setServiceAccountId(String id)
Sets the service account ID (typically an e-mail address).
|
TcpDiscoveryGoogleStorageIpFinder |
TcpDiscoveryGoogleStorageIpFinder.setServiceAccountP12FilePath(String p12FileName)
Sets a full path to the private key in PKCS12 format of the Service Account.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoveryJdbcIpFinder |
TcpDiscoveryJdbcIpFinder.setDataSource(DataSource dataSrc)
Sets data source.
|
TcpDiscoveryJdbcIpFinder |
TcpDiscoveryJdbcIpFinder.setInitSchema(boolean initSchema)
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or
was explicitly created by user.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoveryMulticastIpFinder |
TcpDiscoveryMulticastIpFinder.setAddressRequestAttempts(int addrReqAttempts)
Sets number of attempts to send multicast address request.
|
TcpDiscoveryMulticastIpFinder |
TcpDiscoveryMulticastIpFinder.setLocalAddress(String locAddr)
Sets local host address used by this IP finder.
|
TcpDiscoveryMulticastIpFinder |
TcpDiscoveryMulticastIpFinder.setMulticastGroup(String mcastGrp)
Sets IP address of multicast group.
|
TcpDiscoveryMulticastIpFinder |
TcpDiscoveryMulticastIpFinder.setMulticastPort(int mcastPort)
Sets port number which multicast messages are sent to.
|
TcpDiscoveryMulticastIpFinder |
TcpDiscoveryMulticastIpFinder.setResponseWaitTime(int resWaitTime)
Sets time in milliseconds IP finder waits for reply to
multicast address request.
|
TcpDiscoveryMulticastIpFinder |
TcpDiscoveryMulticastIpFinder.setTimeToLive(int ttl)
Set the default time-to-live for multicast packets sent out on this
IP finder in order to control the scope of the multicast.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoveryS3IpFinder |
TcpDiscoveryS3IpFinder.setAwsCredentials(com.amazonaws.auth.AWSCredentials cred)
Sets AWS credentials.
|
TcpDiscoveryS3IpFinder |
TcpDiscoveryS3IpFinder.setAwsCredentialsProvider(com.amazonaws.auth.AWSCredentialsProvider credProvider)
Sets AWS credentials provider.
|
TcpDiscoveryS3IpFinder |
TcpDiscoveryS3IpFinder.setBucketEndpoint(String bucketEndpoint)
Sets bucket endpoint for IP finder.
|
TcpDiscoveryS3IpFinder |
TcpDiscoveryS3IpFinder.setBucketName(String bucketName)
Sets bucket name for IP finder.
|
TcpDiscoveryS3IpFinder |
TcpDiscoveryS3IpFinder.setClientConfiguration(com.amazonaws.ClientConfiguration cfg)
Sets Amazon client configuration.
|
TcpDiscoveryS3IpFinder |
TcpDiscoveryS3IpFinder.setKeyPrefix(String keyPrefix)
This can be thought of as the sub-folder within the bucket that will hold the node addresses.
|
TcpDiscoveryS3IpFinder |
TcpDiscoveryS3IpFinder.setSSEAlgorithm(String sseAlg)
Sets server-side encryption algorithm for Amazon S3-managed encryption keys.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoverySharedFsIpFinder |
TcpDiscoverySharedFsIpFinder.setPath(String path)
Sets path.
|
Modifier and Type | Method and Description |
---|---|
TcpDiscoveryVmIpFinder |
TcpDiscoveryVmIpFinder.setAddresses(Collection<String> addrs)
Parses provided values and initializes the internal collection of addresses.
|
Modifier and Type | Method and Description |
---|---|
ZookeeperDiscoverySpi |
ZookeeperDiscoverySpi.setClientReconnectDisabled(boolean clientReconnectDisabled)
Sets client reconnect disabled flag.
|
ZookeeperDiscoverySpi |
ZookeeperDiscoverySpi.setJoinTimeout(long joinTimeout) |
ZookeeperDiscoverySpi |
ZookeeperDiscoverySpi.setSessionTimeout(long sesTimeout) |
ZookeeperDiscoverySpi |
ZookeeperDiscoverySpi.setZkConnectionString(String zkConnectionString) |
ZookeeperDiscoverySpi |
ZookeeperDiscoverySpi.setZkRootPath(String zkRootPath) |
Modifier and Type | Method and Description |
---|---|
MemoryEventStorageSpi |
MemoryEventStorageSpi.setExpireAgeMs(long expireAgeMs)
Sets events expiration time.
|
MemoryEventStorageSpi |
MemoryEventStorageSpi.setExpireCount(long expireCnt)
Sets events queue size.
|
MemoryEventStorageSpi |
MemoryEventStorageSpi.setFilter(IgnitePredicate<Event> filter)
Sets filter for events to be recorded.
|
Modifier and Type | Method and Description |
---|---|
AlwaysFailoverSpi |
AlwaysFailoverSpi.setMaximumFailoverAttempts(int maxFailoverAttempts)
Sets maximum number of attempts to execute a failed job on another node.
|
Modifier and Type | Method and Description |
---|---|
JobStealingFailoverSpi |
JobStealingFailoverSpi.setMaximumFailoverAttempts(int maxFailoverAttempts)
Sets maximum number of attempts to execute a failed job on another node.
|
Modifier and Type | Method and Description |
---|---|
AdaptiveLoadBalancingSpi |
AdaptiveLoadBalancingSpi.setLoadProbe(AdaptiveLoadProbe probe)
Sets implementation of node load probe.
|
Modifier and Type | Method and Description |
---|---|
RoundRobinLoadBalancingSpi |
RoundRobinLoadBalancingSpi.setPerTask(boolean isPerTask)
Configuration parameter indicating whether a new round robin order should be
created for every task.
|
Modifier and Type | Method and Description |
---|---|
WeightedRandomLoadBalancingSpi |
WeightedRandomLoadBalancingSpi.setNodeWeight(int nodeWeight)
Sets weight of this node.
|
WeightedRandomLoadBalancingSpi |
WeightedRandomLoadBalancingSpi.setUseWeights(boolean isUseWeights)
Sets a flag to indicate whether node weights should be checked when
doing random load balancing.
|
Follow @ApacheIgnite
Ignite Database and Caching Platform : ver. 2.7.2 Release Date : February 6 2019