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.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.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.
|
org.apache.ignite.spi.swapspace.file |
Contains file-based swap space SPI.
|
Modifier and Type | Method and Description |
---|---|
void |
IgniteSpiAdapter.setName(String name)
Sets SPI name.
|
Modifier and Type | Method and Description |
---|---|
void |
CacheCheckpointSpi.setCacheName(String cacheName)
Sets cache name to be used by this SPI.
|
Modifier and Type | Method and Description |
---|---|
void |
JdbcCheckpointSpi.setCheckpointTableName(String tblName)
Sets checkpoint table name.
|
void |
JdbcCheckpointSpi.setDataSource(DataSource dataSrc)
Sets DataSource to use for database access.
|
void |
JdbcCheckpointSpi.setExpireDateFieldName(String expDateName)
Sets checkpoint expiration date field name.
|
void |
JdbcCheckpointSpi.setExpireDateFieldType(String expDateType)
Sets checkpoint expiration date field type.
|
void |
JdbcCheckpointSpi.setKeyFieldName(String keyName)
Sets checkpoint key field name.
|
void |
JdbcCheckpointSpi.setKeyFieldType(String keyType)
Sets checkpoint key field type.
|
void |
JdbcCheckpointSpi.setNumberOfRetries(int retryNum)
Sets number of retries in case of any database errors.
|
void |
JdbcCheckpointSpi.setPwd(String pwd)
Sets checkpoint database password.
|
void |
JdbcCheckpointSpi.setUser(String user)
Sets checkpoint database user name.
|
void |
JdbcCheckpointSpi.setValueFieldName(String valName)
Sets checkpoint value field name.
|
void |
JdbcCheckpointSpi.setValueFieldType(String valType)
Sets checkpoint value field type.
|
Modifier and Type | Method and Description |
---|---|
void |
S3CheckpointSpi.setAwsCredentials(com.amazonaws.auth.AWSCredentials cred)
Sets AWS credentials.
|
void |
S3CheckpointSpi.setBucketNameSuffix(String bucketNameSuffix)
Sets bucket name suffix.
|
void |
S3CheckpointSpi.setClientConfiguration(com.amazonaws.ClientConfiguration cfg)
Sets Amazon client configuration.
|
Modifier and Type | Method and Description |
---|---|
void |
SharedFsCheckpointSpi.setDirectoryPaths(Collection<String> dirPaths)
Sets path to a shared directory where checkpoints will be stored.
|
Modifier and Type | Method and Description |
---|---|
void |
FifoQueueCollisionSpi.setParallelJobsNumber(int parallelJobsNum)
Sets number of jobs that can be executed in parallel.
|
void |
FifoQueueCollisionSpi.setWaitingJobsNumber(int waitJobsNum)
Sets maximum number of jobs that are allowed to wait in waiting queue.
|
Modifier and Type | Method and Description |
---|---|
void |
JobStealingCollisionSpi.setActiveJobsThreshold(int activeJobsThreshold)
Sets number of jobs that can be executed in parallel.
|
void |
JobStealingCollisionSpi.setMaximumStealingAttempts(int maxStealingAttempts)
Gets maximum number of attempts to steal job by another node.
|
void |
JobStealingCollisionSpi.setMessageExpireTime(long msgExpireTime)
Message expire time configuration parameter.
|
void |
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). |
void |
JobStealingCollisionSpi.setStealingEnabled(boolean isStealingEnabled)
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
|
void |
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 |
---|---|
void |
PriorityQueueCollisionSpi.setDefaultPriority(int dfltPri)
Sets default priority to use if a job does not have priority attribute set.
|
void |
PriorityQueueCollisionSpi.setJobPriorityAttributeKey(String jobPriAttrKey)
Sets job priority attribute key.
|
void |
PriorityQueueCollisionSpi.setParallelJobsNumber(int parallelJobsNum)
Sets number of jobs that can be executed in parallel.
|
void |
PriorityQueueCollisionSpi.setPriorityAttributeKey(String taskPriAttrKey)
Sets task priority attribute key.
|
void |
PriorityQueueCollisionSpi.setStarvationIncrement(int starvationInc)
Sets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
|
void |
PriorityQueueCollisionSpi.setStarvationPreventionEnabled(boolean preventStarvation)
Sets flag indicating whether job starvation prevention is enabled.
|
void |
PriorityQueueCollisionSpi.setWaitingJobsNumber(int waitJobsNum)
Maximum number of jobs that are allowed to wait in waiting queue.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpCommunicationSpi.setAckSendThreshold(int ackSndThreshold)
Sets number of received messages per connection to node after which acknowledgment message is sent.
|
void |
TcpCommunicationSpi.setAddressResolver(AddressResolver addrRslvr)
Sets address resolver.
|
void |
TcpCommunicationSpi.setConnectionBufferFlushFrequency(long connBufFlushFreq)
Sets connection buffer flush frequency.
|
void |
TcpCommunicationSpi.setConnectionBufferSize(int connBufSize)
Sets connection buffer size.
|
void |
TcpCommunicationSpi.setConnectTimeout(long connTimeout)
Sets connect timeout used when establishing connection
with remote nodes.
|
void |
TcpCommunicationSpi.setDirectBuffer(boolean directBuf)
Sets flag to allocate direct or heap buffer in SPI.
|
void |
TcpCommunicationSpi.setDirectSendBuffer(boolean directSndBuf)
Sets whether to use direct buffer for sending.
|
void |
TcpCommunicationSpi.setIdleConnectionTimeout(long idleConnTimeout)
Sets maximum idle connection timeout upon which a connection
to client will be closed.
|
void |
TcpCommunicationSpi.setLocalAddress(String locAddr)
Sets local host address for socket binding.
|
void |
TcpCommunicationSpi.setLocalPort(int locPort)
Sets local port for socket binding.
|
void |
TcpCommunicationSpi.setLocalPortRange(int locPortRange)
Sets local port range for local host ports (value must greater than or equal to 0).
|
void |
TcpCommunicationSpi.setMaxConnectTimeout(long maxConnTimeout)
Sets maximum connect timeout.
|
void |
TcpCommunicationSpi.setMessageQueueLimit(int msgQueueLimit)
Sets message queue limit for incoming and outgoing messages.
|
void |
TcpCommunicationSpi.setMinimumBufferedMessageCount(int minBufferedMsgCnt)
Sets the minimum number of messages for this SPI, that are buffered
prior to sending.
|
void |
TcpCommunicationSpi.setReconnectCount(int reconCnt)
Sets maximum number of reconnect attempts used when establishing connection
with remote nodes.
|
void |
TcpCommunicationSpi.setSelectorsCount(int selectorsCnt)
Sets the count of selectors te be used in TCP server.
|
void |
TcpCommunicationSpi.setSharedMemoryPort(int shmemPort)
Sets local port to accept shared memory connections.
|
void |
TcpCommunicationSpi.setSocketReceiveBuffer(int sockRcvBuf)
Sets receive buffer size for sockets created or accepted by this SPI.
|
void |
TcpCommunicationSpi.setSocketSendBuffer(int sockSndBuf)
Sets send buffer size for sockets created or accepted by this SPI.
|
void |
TcpCommunicationSpi.setSocketWriteTimeout(long sockWriteTimeout)
Sets socket write timeout for TCP connection.
|
void |
TcpCommunicationSpi.setTcpNoDelay(boolean tcpNoDelay)
Sets value for
TCP_NODELAY socket option. |
void |
TcpCommunicationSpi.setUnacknowledgedMessagesBufferSize(int unackedMsgsBufSize)
Sets maximum number of stored unacknowledged messages per connection to node.
|
Modifier and Type | Method and Description |
---|---|
void |
UriDeploymentSpi.setCheckMd5(boolean checkMd5)
If set to
true then SPI should exclude files with same md5s from deployment. |
void |
UriDeploymentSpi.setEncodeUri(boolean encodeUri)
Indicates that URI must be encoded before usage.
|
void |
UriDeploymentSpi.setScanners(org.apache.ignite.spi.deployment.uri.scanners.UriDeploymentScanner... scanners)
Sets scanners.
|
void |
UriDeploymentSpi.setTemporaryDirectoryPath(String tmpDirPath)
Sets absolute path to temporary directory which will be used by
deployment SPI to keep all deployed classes in.
|
void |
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.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setForceServerMode(boolean forceSrvMode)
Sets force server mode flag.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setHeartbeatFrequency(long hbFreq)
Sets delay between issuing of heartbeat messages.
|
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.setMaxMissedClientHeartbeats(int maxMissedClientHbs)
Sets max heartbeats count node can miss without failing client node.
|
TcpDiscoverySpi |
TcpDiscoverySpi.setMaxMissedHeartbeats(int maxMissedHbs)
Sets max heartbeats count node can miss without initiating status check.
|
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.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 |
---|---|
void |
TcpDiscoveryIpFinderAdapter.setShared(boolean shared)
Sets shared flag.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoveryCloudIpFinder.setCredential(String credential)
Sets credential that is used during authentication on the cloud.
|
void |
TcpDiscoveryCloudIpFinder.setCredentialPath(String credentialPath)
Sets the path to a credential that is used during authentication on the cloud.
|
void |
TcpDiscoveryCloudIpFinder.setIdentity(String identity)
Sets the identity that is used as a user name during a connection to the cloud.
|
void |
TcpDiscoveryCloudIpFinder.setProvider(String provider)
Sets the cloud provider to use.
|
void |
TcpDiscoveryCloudIpFinder.setRegions(Collection<String> regions)
Sets list of regions where VMs are located.
|
void |
TcpDiscoveryCloudIpFinder.setZones(Collection<String> zones)
Sets list of zones where VMs are located.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoveryGoogleStorageIpFinder.setBucketName(String bucketName)
Sets Google Cloud Storage bucket name.
|
void |
TcpDiscoveryGoogleStorageIpFinder.setProjectName(String projectName)
Sets Google Cloud Platforms project name.
|
void |
TcpDiscoveryGoogleStorageIpFinder.setServiceAccountId(String id)
Sets the service account ID (typically an e-mail address).
|
void |
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 |
---|---|
void |
TcpDiscoveryJdbcIpFinder.setDataSource(DataSource dataSrc)
Sets data source.
|
void |
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 |
---|---|
void |
TcpDiscoveryMulticastIpFinder.setAddressRequestAttempts(int addrReqAttempts)
Sets number of attempts to send multicast address request.
|
void |
TcpDiscoveryMulticastIpFinder.setLocalAddress(String locAddr)
Sets local host address used by this IP finder.
|
void |
TcpDiscoveryMulticastIpFinder.setMulticastGroup(String mcastGrp)
Sets IP address of multicast group.
|
void |
TcpDiscoveryMulticastIpFinder.setMulticastPort(int mcastPort)
Sets port number which multicast messages are sent to.
|
void |
TcpDiscoveryMulticastIpFinder.setResponseWaitTime(int resWaitTime)
Sets time in milliseconds IP finder waits for reply to
multicast address request.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoveryS3IpFinder.setAwsCredentials(com.amazonaws.auth.AWSCredentials cred)
Sets AWS credentials.
|
void |
TcpDiscoveryS3IpFinder.setBucketName(String bucketName)
Sets bucket name for IP finder.
|
void |
TcpDiscoveryS3IpFinder.setClientConfiguration(com.amazonaws.ClientConfiguration cfg)
Sets Amazon client configuration.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoverySharedFsIpFinder.setPath(String path)
Sets path.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoveryVmIpFinder.setAddresses(Collection<String> addrs)
Parses provided values and initializes the internal collection of addresses.
|
Modifier and Type | Method and Description |
---|---|
void |
MemoryEventStorageSpi.setExpireAgeMs(long expireAgeMs)
Sets events expiration time.
|
void |
MemoryEventStorageSpi.setExpireCount(long expireCnt)
Sets events queue size.
|
void |
MemoryEventStorageSpi.setFilter(IgnitePredicate<Event> filter)
Sets filter for events to be recorded.
|
Modifier and Type | Method and Description |
---|---|
void |
AlwaysFailoverSpi.setMaximumFailoverAttempts(int maxFailoverAttempts)
Sets maximum number of attempts to execute a failed job on another node.
|
Modifier and Type | Method and Description |
---|---|
void |
JobStealingFailoverSpi.setMaximumFailoverAttempts(int maxFailoverAttempts)
Sets maximum number of attempts to execute a failed job on another node.
|
Modifier and Type | Method and Description |
---|---|
void |
AdaptiveLoadBalancingSpi.setLoadProbe(AdaptiveLoadProbe probe)
Sets implementation of node load probe.
|
Modifier and Type | Method and Description |
---|---|
void |
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 |
---|---|
void |
WeightedRandomLoadBalancingSpi.setNodeWeight(int nodeWeight)
Sets weight of this node.
|
void |
WeightedRandomLoadBalancingSpi.setUseWeights(boolean isUseWeights)
Sets a flag to indicate whether node weights should be checked when
doing random load balancing.
|
Modifier and Type | Method and Description |
---|---|
void |
FileSwapSpaceSpi.setBaseDirectory(String baseDir)
Sets base directory.
|
Follow @ApacheIgnite
Ignite Fabric : ver. 1.2.0-incubating Release Date : June 16 2015