Package | Description |
---|---|
org.apache.ignite.cache.eviction.fifo |
Contains cache FIFO eviction policy implementations.
|
org.apache.ignite.cache.eviction.igfs |
Contains IGFS LRU eviction policy implementations.
|
org.apache.ignite.cache.eviction.lru |
Contains cache LRU eviction policy implementations.
|
org.apache.ignite.cache.eviction.random |
Contains cache randomized eviction policy implementations.
|
org.apache.ignite.cache.eviction.sorted |
Contains cache sorted eviction policy implementation.
|
org.apache.ignite.mxbean |
Contains annotations for Dynamic MBeans.
|
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.local |
Contains default local deployment SPI implementation.
|
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.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.failover.never |
Contains "never" 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 | Interface and Description |
---|---|
interface |
FifoEvictionPolicyMBean
MBean for
FIFO eviction policy. |
Modifier and Type | Method and Description |
---|---|
int |
FifoEvictionPolicyMBean.getBatchSize()
Gets batch size.
|
long |
FifoEvictionPolicyMBean.getCurrentMemorySize()
Gets current queue size in bytes.
|
int |
FifoEvictionPolicyMBean.getCurrentSize()
Gets current queue size.
|
long |
FifoEvictionPolicyMBean.getMaxMemorySize()
Gets maximum allowed cache size in bytes.
|
int |
FifoEvictionPolicyMBean.getMaxSize()
Gets maximum allowed cache size.
|
void |
FifoEvictionPolicyMBean.setBatchSize(int batchSize)
Sets batch size.
|
void |
FifoEvictionPolicyMBean.setMaxMemorySize(long maxMemSize)
Sets maximum allowed cache size in bytes.
|
void |
FifoEvictionPolicyMBean.setMaxSize(int max)
Sets maximum allowed cache size.
|
Modifier and Type | Interface and Description |
---|---|
interface |
IgfsPerBlockLruEvictionPolicyMXBean
MBean for
IGFS per-block LRU eviction policy. |
Modifier and Type | Method and Description |
---|---|
int |
IgfsPerBlockLruEvictionPolicyMXBean.getCurrentBlocks()
Gets current amount of blocks.
|
long |
IgfsPerBlockLruEvictionPolicyMXBean.getCurrentSize()
Gets current size of data in all blocks.
|
Collection<String> |
IgfsPerBlockLruEvictionPolicyMXBean.getExcludePaths()
Gets collection of regex for paths whose blocks must not be evicted.
|
int |
IgfsPerBlockLruEvictionPolicyMXBean.getMaxBlocks()
Gets maximum allowed amount of blocks.
|
long |
IgfsPerBlockLruEvictionPolicyMXBean.getMaxSize()
Gets maximum allowed size of all blocks in bytes.
|
void |
IgfsPerBlockLruEvictionPolicyMXBean.setExcludePaths(Collection<String> excludePaths)
Sets collection of regex for paths whose blocks must not be evicted.
|
void |
IgfsPerBlockLruEvictionPolicyMXBean.setMaxBlocks(int maxBlocks)
Sets maximum allowed amount of blocks.
|
void |
IgfsPerBlockLruEvictionPolicyMXBean.setMaxSize(long maxSize)
Sets maximum allowed size of data in all blocks in bytes.
|
Modifier and Type | Interface and Description |
---|---|
interface |
LruEvictionPolicyMBean
MBean for
LRU eviction policy. |
Modifier and Type | Method and Description |
---|---|
int |
LruEvictionPolicyMBean.getBatchSize()
Gets batch size.
|
long |
LruEvictionPolicyMBean.getCurrentMemorySize()
Gets current queue size in bytes.
|
int |
LruEvictionPolicyMBean.getCurrentSize()
Gets current queue size.
|
long |
LruEvictionPolicyMBean.getMaxMemorySize()
Gets maximum allowed cache size in bytes.
|
int |
LruEvictionPolicyMBean.getMaxSize()
Gets maximum allowed cache size.
|
void |
LruEvictionPolicyMBean.setBatchSize(int batchSize)
Sets batch size.
|
void |
LruEvictionPolicyMBean.setMaxMemorySize(long maxMemSize)
Sets maximum allowed cache size in bytes.
|
void |
LruEvictionPolicyMBean.setMaxSize(int max)
Sets maximum allowed cache size.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RandomEvictionPolicyMBean
MBean for
random eviction policy. |
Modifier and Type | Method and Description |
---|---|
int |
RandomEvictionPolicyMBean.getMaxSize()
Gets maximum allowed cache size.
|
void |
RandomEvictionPolicyMBean.setMaxSize(int max)
Sets maximum allowed cache size.
|
Modifier and Type | Interface and Description |
---|---|
interface |
SortedEvictionPolicyMBean
MBean for sorted eviction policy.
|
Modifier and Type | Method and Description |
---|---|
int |
SortedEvictionPolicyMBean.getBatchSize()
Gets batch size.
|
long |
SortedEvictionPolicyMBean.getCurrentMemorySize()
Gets current sorted entries queue size in bytes.
|
int |
SortedEvictionPolicyMBean.getCurrentSize()
Gets current size.
|
long |
SortedEvictionPolicyMBean.getMaxMemorySize()
Gets maximum allowed cache size in bytes.
|
int |
SortedEvictionPolicyMBean.getMaxSize()
Gets maximum allowed cache size.
|
void |
SortedEvictionPolicyMBean.setBatchSize(int batchSize)
Sets batch size.
|
void |
SortedEvictionPolicyMBean.setMaxMemorySize(long maxMemSize)
Sets maximum allowed cache size in bytes.
|
void |
SortedEvictionPolicyMBean.setMaxSize(int max)
Sets maximum allowed cache size.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CacheMetricsMXBean
This interface defines JMX view on
IgniteCache . |
interface |
ClusterLocalNodeMetricsMXBean
MBean for local node metrics.
|
interface |
IgniteMXBean
This interface defines JMX view on kernal.
|
interface |
IgnitionMXBean
This interface defines JMX view on
Ignition . |
interface |
ThreadPoolMXBean
MBean that provides access to information about executor service.
|
Modifier and Type | Method and Description |
---|---|
void |
CacheMetricsMXBean.clear() |
String |
IgniteMXBean.executeTask(String taskName,
String arg)
A shortcut method that executes given task assuming single
java.lang.String argument
and java.lang.String return type. |
int |
ThreadPoolMXBean.getActiveCount()
Returns the approximate number of threads that are actively executing tasks.
|
float |
ClusterLocalNodeMetricsMXBean.getAverageActiveJobs()
Gets average number of active jobs concurrently executing on the node.
|
float |
ClusterLocalNodeMetricsMXBean.getAverageCancelledJobs()
Gets average number of cancelled jobs this node ever had running
concurrently.
|
double |
ClusterLocalNodeMetricsMXBean.getAverageCpuLoad()
Gets average of CPU load values over all metrics kept in the history.
|
float |
CacheMetricsMXBean.getAverageGetTime()
The mean time to execute gets.
|
double |
ClusterLocalNodeMetricsMXBean.getAverageJobExecuteTime()
Gets average time a job takes to execute on the node.
|
double |
ClusterLocalNodeMetricsMXBean.getAverageJobWaitTime()
Gets average time jobs spend waiting in the queue to be executed.
|
float |
CacheMetricsMXBean.getAveragePutTime()
The mean time to execute puts.
|
float |
ClusterLocalNodeMetricsMXBean.getAverageRejectedJobs()
Gets average number of jobs this node rejects during collision resolution operations.
|
float |
CacheMetricsMXBean.getAverageRemoveTime()
The mean time to execute removes.
|
float |
CacheMetricsMXBean.getAverageTxCommitTime()
The mean time to execute tx commit.
|
float |
CacheMetricsMXBean.getAverageTxRollbackTime()
The mean time to execute tx rollbacks.
|
float |
ClusterLocalNodeMetricsMXBean.getAverageWaitingJobs()
Gets average number of waiting jobs this node had queued.
|
float |
ClusterLocalNodeMetricsMXBean.getBusyTimePercentage()
Gets percentage of time this node is busy executing jobs vs. idling.
|
long |
CacheMetricsMXBean.getCacheEvictions()
The total number of evictions from the cache.
|
long |
CacheMetricsMXBean.getCacheGets()
The total number of requests to the cache.
|
float |
CacheMetricsMXBean.getCacheHitPercentage()
This is a measure of cache efficiency.
|
long |
CacheMetricsMXBean.getCacheHits()
The number of get requests that were satisfied by the cache.
|
long |
CacheMetricsMXBean.getCacheMisses()
A miss is a get request that is not satisfied.
|
float |
CacheMetricsMXBean.getCacheMissPercentage()
Returns the percentage of cache accesses that did not find a requested entry
in the cache.
|
long |
CacheMetricsMXBean.getCachePuts()
The total number of puts to the cache.
|
long |
CacheMetricsMXBean.getCacheRemovals()
The total number of removals from the cache.
|
long |
CacheMetricsMXBean.getCacheTxCommits()
Gets total number of transaction commits.
|
long |
CacheMetricsMXBean.getCacheTxRollbacks()
Gets total number of transaction rollbacks.
|
String |
IgniteMXBean.getCheckpointSpiFormatted()
Gets a formatted instance of configured checkpoint SPI implementation.
|
String |
IgniteMXBean.getCollisionSpiFormatted()
Gets a formatted instance of configured collision SPI implementations.
|
String |
IgniteMXBean.getCommunicationSpiFormatted()
Gets a formatted instance of fully configured SPI communication implementation.
|
long |
ThreadPoolMXBean.getCompletedTaskCount()
Returns the approximate total number of tasks that have completed execution.
|
String |
IgniteMXBean.getCopyright()
Gets copyright statement for Ignite product.
|
int |
ThreadPoolMXBean.getCorePoolSize()
Returns the core number of threads.
|
int |
ClusterLocalNodeMetricsMXBean.getCurrentActiveJobs()
Gets number of currently active jobs concurrently executing on the node.
|
int |
ClusterLocalNodeMetricsMXBean.getCurrentCancelledJobs()
Gets number of cancelled jobs that are still running.
|
double |
ClusterLocalNodeMetricsMXBean.getCurrentCpuLoad()
Returns the CPU usage usage in
[0, 1] range. |
int |
ClusterLocalNodeMetricsMXBean.getCurrentDaemonThreadCount()
Returns the current number of live daemon threads.
|
double |
ClusterLocalNodeMetricsMXBean.getCurrentGcCpuLoad()
Returns average time spent in CG since the last update.
|
long |
ClusterLocalNodeMetricsMXBean.getCurrentIdleTime()
Gets time this node spend idling since executing last job.
|
long |
ClusterLocalNodeMetricsMXBean.getCurrentJobExecuteTime()
Gets longest time a current job has been executing for.
|
long |
ClusterLocalNodeMetricsMXBean.getCurrentJobWaitTime()
Gets current time an oldest jobs has spent waiting to be executed.
|
int |
ClusterLocalNodeMetricsMXBean.getCurrentRejectedJobs()
Gets number of jobs rejected after more recent collision resolution operation.
|
int |
ClusterLocalNodeMetricsMXBean.getCurrentThreadCount()
Returns the current number of live threads including both
daemon and non-daemon threads.
|
int |
ClusterLocalNodeMetricsMXBean.getCurrentWaitingJobs()
Gets number of queued jobs currently waiting to be executed.
|
String |
IgniteMXBean.getDeploymentSpiFormatted()
Gets a formatted instance of fully configured deployment SPI implementation.
|
int |
CacheMetricsMXBean.getDhtEvictQueueCurrentSize()
Gets current size of evict queue used to batch up evictions.
|
String |
IgniteMXBean.getDiscoverySpiFormatted()
Gets a formatted instance of configured discovery SPI implementation.
|
String |
IgniteMXBean.getEventStorageSpiFormatted()
Gets a formatted instance of fully configured event SPI implementation.
|
String |
IgniteMXBean.getExecutorServiceFormatted()
Gets a formatted instance of fully configured thread pool that is used in grid.
|
String |
IgniteMXBean.getFailoverSpiFormatted()
Gets a formatted instance of fully configured failover SPI implementations.
|
String |
IgniteMXBean.getFullVersion()
Gets string presentation of the version.
|
String |
IgniteMXBean.getGridLoggerFormatted()
Gets a formatted instance of logger that is in grid.
|
long |
ClusterLocalNodeMetricsMXBean.getHeapMemoryCommitted()
Returns the amount of heap memory in bytes that is committed for
the JVM to use.
|
long |
ClusterLocalNodeMetricsMXBean.getHeapMemoryInitialized()
Returns the amount of heap memory in bytes that the JVM
initially requests from the operating system for memory management.
|
long |
ClusterLocalNodeMetricsMXBean.getHeapMemoryMaximum()
Returns the maximum amount of heap memory in bytes that can be
used for memory management.
|
long |
ClusterLocalNodeMetricsMXBean.getHeapMemoryTotal()
Returns the total amount of heap memory in bytes.
|
long |
ClusterLocalNodeMetricsMXBean.getHeapMemoryUsed()
Returns the current heap size that is used for object allocation.
|
float |
ClusterLocalNodeMetricsMXBean.getIdleTimePercentage()
Gets percentage of time this node is idling vs. executing jobs.
|
String |
IgniteMXBean.getIgniteHome()
Gets Ignite installation home folder.
|
String |
IgniteMXBean.getInstanceName()
Gets optional kernal instance name.
|
String |
IgniteMXBean.getJdkInformation()
Gets JDK information.
|
long |
ThreadPoolMXBean.getKeepAliveTime()
Returns the thread keep-alive time, which is the amount of time which threads
in excess of the core pool size may remain idle before being terminated.
|
int |
CacheMetricsMXBean.getKeySize()
Gets number of keys in the cache, possibly with
null values. |
String |
CacheMetricsMXBean.getKeyType()
Determines the required type of keys for this
Cache , if any. |
int |
ThreadPoolMXBean.getLargestPoolSize()
Returns the largest number of threads that have ever
simultaneously been in the pool.
|
long |
ClusterLocalNodeMetricsMXBean.getLastDataVersion()
In-Memory Data Grid assigns incremental versions to all cache operations.
|
long |
ClusterLocalNodeMetricsMXBean.getLastUpdateTime()
Gets last update time of this node metrics.
|
Collection<String> |
IgniteMXBean.getLifecycleBeansFormatted()
Gets
toString() representation of of lifecycle beans configured
with Ignite. |
String |
IgniteMXBean.getLoadBalancingSpiFormatted()
Gets a formatted instance of fully configured load balancing SPI implementations.
|
UUID |
IgniteMXBean.getLocalNodeId()
Unique identifier for this node within grid.
|
int |
ClusterLocalNodeMetricsMXBean.getMaximumActiveJobs()
Gets maximum number of jobs that ever ran concurrently on this node.
|
int |
ClusterLocalNodeMetricsMXBean.getMaximumCancelledJobs()
Gets maximum number of cancelled jobs this node ever had running
concurrently.
|
long |
ClusterLocalNodeMetricsMXBean.getMaximumJobExecuteTime()
Gets time it took to execute the longest job on the node.
|
long |
ClusterLocalNodeMetricsMXBean.getMaximumJobWaitTime()
Gets maximum time a job ever spent waiting in a queue to be executed.
|
int |
ThreadPoolMXBean.getMaximumPoolSize()
Returns the maximum allowed number of threads.
|
int |
ClusterLocalNodeMetricsMXBean.getMaximumRejectedJobs()
Gets maximum number of jobs rejected at once during a single collision resolution
operation.
|
int |
ClusterLocalNodeMetricsMXBean.getMaximumThreadCount()
Returns the maximum live thread count since the JVM
started or peak was reset.
|
int |
ClusterLocalNodeMetricsMXBean.getMaximumWaitingJobs()
Gets maximum number of waiting jobs this node had.
|
String |
IgniteMXBean.getMBeanServerFormatted()
Gets a formatted instance of MBean server instance.
|
long |
ClusterLocalNodeMetricsMXBean.getNodeStartTime()
Returns the start time of grid node in milliseconds.
|
long |
ClusterLocalNodeMetricsMXBean.getNonHeapMemoryCommitted()
Returns the amount of non-heap memory in bytes that is committed for
the JVM to use.
|
long |
ClusterLocalNodeMetricsMXBean.getNonHeapMemoryInitialized()
Returns the amount of non-heap memory in bytes that the JVM
initially requests from the operating system for memory management.
|
long |
ClusterLocalNodeMetricsMXBean.getNonHeapMemoryMaximum()
Returns the maximum amount of non-heap memory in bytes that can be
used for memory management.
|
long |
ClusterLocalNodeMetricsMXBean.getNonHeapMemoryTotal()
Returns the total amount of non-heap memory in bytes that can be
used for memory management.
|
long |
ClusterLocalNodeMetricsMXBean.getNonHeapMemoryUsed()
Returns the current non-heap memory size that is used by Java VM.
|
long |
CacheMetricsMXBean.getOffHeapAllocatedSize()
Gets memory size allocated in off-heap.
|
long |
CacheMetricsMXBean.getOffHeapBackupEntriesCount()
Gets number of backup entries stored in off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapEntriesCount()
Gets number of entries stored in off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapEvictions()
The total number of evictions from the off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapGets()
The total number of get requests to the off-heap memory.
|
float |
CacheMetricsMXBean.getOffHeapHitPercentage()
Gets the percentage of hits on off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapHits()
The number of get requests that were satisfied by the off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapMaxSize()
Gets off-heap memory maximum size.
|
long |
CacheMetricsMXBean.getOffHeapMisses()
A miss is a get request that is not satisfied by off-heap memory.
|
float |
CacheMetricsMXBean.getOffHeapMissPercentage()
Gets the percentage of misses on off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapPrimaryEntriesCount()
Gets number of primary entries stored in off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapPuts()
The total number of put requests to the off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapRemovals()
The total number of removals from the off-heap memory.
|
String |
IgniteMXBean.getOsInformation()
Gets OS information.
|
String |
IgniteMXBean.getOsUser()
Gets OS user.
|
int |
ClusterLocalNodeMetricsMXBean.getOutboundMessagesQueueSize()
Gets outbound messages queue size.
|
long |
CacheMetricsMXBean.getOverflowSize()
Gets number of entries that was swapped to disk.
|
int |
ThreadPoolMXBean.getPoolSize()
Returns the current number of threads in the pool.
|
int |
ThreadPoolMXBean.getQueueSize()
Gets current size of the execution queue.
|
long |
ClusterLocalNodeMetricsMXBean.getReceivedBytesCount()
Gets received bytes count.
|
int |
ClusterLocalNodeMetricsMXBean.getReceivedMessagesCount()
Gets received messages count.
|
String |
ThreadPoolMXBean.getRejectedExecutionHandlerClass()
Returns the class name of current rejection handler.
|
long |
ClusterLocalNodeMetricsMXBean.getSentBytesCount()
Gets sent bytes count.
|
int |
ClusterLocalNodeMetricsMXBean.getSentMessagesCount()
Gets sent messages count.
|
int |
CacheMetricsMXBean.getSize()
Gets number of non-
null values in the cache. |
long |
ClusterLocalNodeMetricsMXBean.getStartTime()
Returns the start time of the JVM in milliseconds.
|
long |
IgniteMXBean.getStartTimestamp()
Get start timestamp of the kernal.
|
String |
IgniteMXBean.getStartTimestampFormatted()
Gets string presentation of the kernal start timestamp.
|
String |
IgnitionMXBean.getState()
Gets state of default grid instance.
|
String |
IgnitionMXBean.getState(String name)
Gets state for a given grid instance.
|
long |
CacheMetricsMXBean.getSwapEntriesCount()
Gets number of entries stored in swap.
|
long |
CacheMetricsMXBean.getSwapGets()
The total number of get requests to the swap.
|
float |
CacheMetricsMXBean.getSwapHitPercentage()
Gets the percentage of hits on swap.
|
long |
CacheMetricsMXBean.getSwapHits()
The number of get requests that were satisfied by the swap.
|
long |
CacheMetricsMXBean.getSwapMisses()
A miss is a get request that is not satisfied by swap.
|
float |
CacheMetricsMXBean.getSwapMissPercentage()
Gets the percentage of misses on swap.
|
long |
CacheMetricsMXBean.getSwapPuts()
The total number of put requests to the swap.
|
long |
CacheMetricsMXBean.getSwapRemovals()
The total number of removals from the swap.
|
long |
CacheMetricsMXBean.getSwapSize()
Gets size of swap.
|
String |
IgniteMXBean.getSwapSpaceSpiFormatted()
Gets a formatted instance of configured swapspace SPI implementations.
|
long |
ThreadPoolMXBean.getTaskCount()
Returns the approximate total number of tasks that have been scheduled
for execution.
|
String |
ThreadPoolMXBean.getThreadFactoryClass()
Returns the class name of thread factory used to create new threads.
|
long |
ClusterLocalNodeMetricsMXBean.getTotalBusyTime()
Gets total time this node spent executing jobs.
|
int |
ClusterLocalNodeMetricsMXBean.getTotalCancelledJobs()
Gets number of cancelled jobs since node startup.
|
int |
ClusterLocalNodeMetricsMXBean.getTotalCpus()
Returns the number of CPUs available to the Java Virtual Machine.
|
int |
ClusterLocalNodeMetricsMXBean.getTotalExecutedJobs()
Gets total number of jobs handled by the node since node startup.
|
int |
ClusterLocalNodeMetricsMXBean.getTotalExecutedTasks()
Gets total number of tasks handled by the node.
|
long |
ClusterLocalNodeMetricsMXBean.getTotalIdleTime()
Gets total time this node spent idling (not executing any jobs).
|
int |
ClusterLocalNodeMetricsMXBean.getTotalNodes()
Gets total number of nodes.
|
int |
ClusterLocalNodeMetricsMXBean.getTotalRejectedJobs()
Gets total number of jobs this node rejects during collision resolution operations since node startup.
|
long |
ClusterLocalNodeMetricsMXBean.getTotalStartedThreadCount()
Returns the total number of threads created and also started
since the JVM started.
|
int |
CacheMetricsMXBean.getTxCommitQueueSize()
Gets committed transaction queue size.
|
int |
CacheMetricsMXBean.getTxCommittedVersionsSize()
Gets number of cached committed transaction IDs.
|
int |
CacheMetricsMXBean.getTxDhtCommitQueueSize()
Gets committed DHT transaction queue size.
|
int |
CacheMetricsMXBean.getTxDhtCommittedVersionsSize()
Gets number of cached committed DHT transaction IDs.
|
int |
CacheMetricsMXBean.getTxDhtPrepareQueueSize()
Gets prepared DHT transaction queue size.
|
int |
CacheMetricsMXBean.getTxDhtRolledbackVersionsSize()
Gets number of cached rolled back DHT transaction IDs.
|
int |
CacheMetricsMXBean.getTxDhtStartVersionCountsSize()
Gets DHT start version counts map size.
|
int |
CacheMetricsMXBean.getTxDhtThreadMapSize()
Gets transaction DHT per-thread map size.
|
int |
CacheMetricsMXBean.getTxDhtXidMapSize()
Gets transaction DHT per-Xid map size.
|
int |
CacheMetricsMXBean.getTxPrepareQueueSize()
Gets prepared transaction queue size.
|
int |
CacheMetricsMXBean.getTxRolledbackVersionsSize()
Gets number of cached rolled back transaction IDs.
|
int |
CacheMetricsMXBean.getTxStartVersionCountsSize()
Gets start version counts map size.
|
int |
CacheMetricsMXBean.getTxThreadMapSize()
Gets transaction per-thread map size.
|
int |
CacheMetricsMXBean.getTxXidMapSize()
Gets transaction per-Xid map size.
|
long |
IgniteMXBean.getUpTime()
Gets up-time of the kernal.
|
long |
ClusterLocalNodeMetricsMXBean.getUpTime()
Returns the uptime of the JVM in milliseconds.
|
String |
IgniteMXBean.getUpTimeFormatted()
Gets string presentation of up-time for the kernal.
|
Collection<String> |
IgniteMXBean.getUserAttributesFormatted()
Gets a collection of formatted user-defined attributes added to this node.
|
String |
CacheMetricsMXBean.getValueType()
Determines the required type of values for this
Cache , if any. |
String |
IgniteMXBean.getVmName()
Gets VM name.
|
int |
CacheMetricsMXBean.getWriteBehindBufferSize()
Gets count of entries that were processed by the write-behind store and have not been
flushed to the underlying store yet.
|
int |
CacheMetricsMXBean.getWriteBehindCriticalOverflowCount()
Gets count of write buffer overflow events in progress at the moment.
|
int |
CacheMetricsMXBean.getWriteBehindErrorRetryCount()
Gets count of cache entries that are in a store-retry state.
|
long |
CacheMetricsMXBean.getWriteBehindFlushFrequency()
Gets the cache flush frequency.
|
int |
CacheMetricsMXBean.getWriteBehindFlushSize()
Gets the maximum size of the write-behind buffer.
|
int |
CacheMetricsMXBean.getWriteBehindFlushThreadCount()
Gets the number of flush threads that will perform store update operations.
|
int |
CacheMetricsMXBean.getWriteBehindStoreBatchSize()
Gets the maximum count of similar (put or remove) operations that can be grouped to a single batch.
|
int |
CacheMetricsMXBean.getWriteBehindTotalCriticalOverflowCount()
Gets count of write buffer overflow events since initialization.
|
boolean |
CacheMetricsMXBean.isEmpty()
Returns
true if this cache is empty. |
boolean |
CacheMetricsMXBean.isManagementEnabled()
Checks whether management is enabled on this cache.
|
boolean |
IgniteMXBean.isPeerClassLoadingEnabled()
Returns
true if peer class loading is enabled, false
otherwise. |
boolean |
CacheMetricsMXBean.isReadThrough()
Determines if a
Cache should operate in read-through mode. |
boolean |
ThreadPoolMXBean.isShutdown()
Returns
true if this executor has been shut down. |
boolean |
CacheMetricsMXBean.isStatisticsEnabled()
Checks whether statistics collection is enabled in this cache.
|
boolean |
CacheMetricsMXBean.isStoreByValue()
Whether storeByValue
true or storeByReference false . |
boolean |
ThreadPoolMXBean.isTerminated()
Returns
true if all tasks have completed following shut down. |
boolean |
ThreadPoolMXBean.isTerminating()
Returns
true if this executor is in the process of terminating after
shutdown() or shutdownNow() but has not completely terminated. |
boolean |
CacheMetricsMXBean.isWriteBehindEnabled()
Returns
true if write-behind is enabled. |
boolean |
CacheMetricsMXBean.isWriteThrough()
Determines if a
Cache should operate in "write-through"
mode. |
String |
CacheMetricsMXBean.name()
Gets name of this cache.
|
boolean |
IgniteMXBean.pingNode(String nodeId)
Pings node with given node ID to see whether it is alive.
|
boolean |
IgniteMXBean.pingNodeByAddress(String host)
Pings node with given host name to see if it is alive.
|
void |
IgniteMXBean.printLastErrors()
Prints errors.
|
boolean |
IgniteMXBean.removeCheckpoint(String key)
This method allows manually remove the checkpoint with given
key . |
void |
IgnitionMXBean.restart(boolean cancel)
Restart JVM.
|
boolean |
IgnitionMXBean.stop(boolean cancel)
Stops default grid instance.
|
boolean |
IgnitionMXBean.stop(String name,
boolean cancel)
Stops named grid.
|
void |
IgnitionMXBean.stopAll(boolean cancel)
Stops all started grids.
|
void |
IgniteMXBean.undeployTaskFromGrid(String taskName)
Makes the best attempt to undeploy a task from the whole grid.
|
Modifier and Type | Method and Description |
---|---|
String |
IgniteSpiManagementMBean.getIgniteHome()
Gets Ignite installation home folder (i.e.
|
UUID |
IgniteSpiManagementMBean.getLocalNodeId()
Gets ID of the local node.
|
String |
IgniteSpiManagementMBean.getName()
Gets name of the SPI.
|
long |
IgniteSpiManagementMBean.getStartTimestamp()
Get start timestamp of this SPI.
|
String |
IgniteSpiManagementMBean.getStartTimestampFormatted()
Gets string presentation of the start timestamp.
|
long |
IgniteSpiManagementMBean.getUpTime()
Gets up-time of this SPI in ms.
|
String |
IgniteSpiManagementMBean.getUpTimeFormatted()
Gets string presentation of up-time for this SPI.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CacheCheckpointSpiMBean
Management bean that provides general administrative and configuration information
about cache checkpoint SPI.
|
Modifier and Type | Method and Description |
---|---|
String |
CacheCheckpointSpiMBean.getCacheName()
Gets cache name to be used by this SPI..
|
Modifier and Type | Interface and Description |
---|---|
interface |
JdbcCheckpointSpiMBean
Management bean that provides general administrative and configuration information
about jdbc checkpoint SPI.
|
Modifier and Type | Method and Description |
---|---|
String |
JdbcCheckpointSpiMBean.getCheckpointTableName()
Gets checkpoint table name.
|
String |
JdbcCheckpointSpiMBean.getDataSourceInfo()
Gets data source description.
|
String |
JdbcCheckpointSpiMBean.getExpireDateFieldName()
Gets expiration date field name for checkpoint table.
|
String |
JdbcCheckpointSpiMBean.getExpireDateFieldType()
Gets expiration date field type for checkpoint table.
|
String |
JdbcCheckpointSpiMBean.getKeyFieldName()
Gets key field name for checkpoint table.
|
String |
JdbcCheckpointSpiMBean.getKeyFieldType()
Gets key field type for checkpoint table.
|
int |
JdbcCheckpointSpiMBean.getNumberOfRetries()
Gets number of retries in case of DB failure.
|
String |
JdbcCheckpointSpiMBean.getPwd()
Gets checkpoint jdbc password.
|
String |
JdbcCheckpointSpiMBean.getUser()
Gets checkpoint jdbc user name.
|
String |
JdbcCheckpointSpiMBean.getValueFieldName()
Gets value field name for checkpoint table.
|
String |
JdbcCheckpointSpiMBean.getValueFieldType()
Gets value field type for checkpoint table.
|
Modifier and Type | Interface and Description |
---|---|
interface |
S3CheckpointSpiMBean
Management bean for
S3CheckpointSpi . |
Modifier and Type | Method and Description |
---|---|
String |
S3CheckpointSpiMBean.getAccessKey() |
String |
S3CheckpointSpiMBean.getBucketName()
Gets S3 bucket name to use.
|
String |
S3CheckpointSpiMBean.getProxyHost() |
int |
S3CheckpointSpiMBean.getProxyPort() |
String |
S3CheckpointSpiMBean.getProxyUsername() |
Modifier and Type | Interface and Description |
---|---|
interface |
SharedFsCheckpointSpiMBean
Management bean that provides general administrative and configuration information
about shared file system checkpoints.
|
Modifier and Type | Method and Description |
---|---|
String |
SharedFsCheckpointSpiMBean.getCurrentDirectoryPath()
Gets path to the directory where all checkpoints are saved.
|
Collection<String> |
SharedFsCheckpointSpiMBean.getDirectoryPaths()
Gets collection of all configured paths where checkpoints can be saved.
|
Modifier and Type | Interface and Description |
---|---|
interface |
FifoQueueCollisionSpiMBean
Management bean that provides access to the FIFO queue collision SPI configuration.
|
Modifier and Type | Method and Description |
---|---|
int |
FifoQueueCollisionSpiMBean.getCurrentActiveJobsNumber()
Gets current number of jobs that are active, i.e.
|
int |
FifoQueueCollisionSpiMBean.getCurrentHeldJobsNumber()
Gets number of currently
'held' jobs. |
int |
FifoQueueCollisionSpiMBean.getCurrentRunningJobsNumber() |
int |
FifoQueueCollisionSpiMBean.getCurrentWaitJobsNumber()
Gets current number of jobs that wait for the execution.
|
int |
FifoQueueCollisionSpiMBean.getParallelJobsNumber()
Gets number of jobs that can be executed in parallel.
|
int |
FifoQueueCollisionSpiMBean.getWaitingJobsNumber()
Maximum number of jobs that are allowed to wait in waiting queue.
|
void |
FifoQueueCollisionSpiMBean.setParallelJobsNumber(int num)
Sets number of jobs that can be executed in parallel.
|
void |
FifoQueueCollisionSpiMBean.setWaitingJobsNumber(int num)
Sets maximum number of jobs that are allowed to wait in waiting queue.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JobStealingCollisionSpiMBean
Management MBean for job stealing based collision SPI.
|
Modifier and Type | Method and Description |
---|---|
int |
JobStealingCollisionSpiMBean.getActiveJobsThreshold()
Gets number of jobs that can be executed in parallel.
|
int |
JobStealingCollisionSpiMBean.getCurrentActiveJobsNumber()
Gets current number of jobs that are being executed.
|
int |
JobStealingCollisionSpiMBean.getCurrentHeldJobsNumber()
Gets number of currently
'held' jobs. |
int |
JobStealingCollisionSpiMBean.getCurrentJobsToStealNumber()
Gets current number of jobs to be stolen.
|
int |
JobStealingCollisionSpiMBean.getCurrentRunningJobsNumber() |
int |
JobStealingCollisionSpiMBean.getCurrentWaitJobsNumber()
Gets current number of jobs that wait for the execution.
|
int |
JobStealingCollisionSpiMBean.getMaximumStealingAttempts()
Gets maximum number of attempts to steal job by another node.
|
long |
JobStealingCollisionSpiMBean.getMessageExpireTime()
Message expire time configuration parameter.
|
Map<String,? extends Serializable> |
JobStealingCollisionSpiMBean.getStealingAttributes()
Configuration parameter to enable stealing to/from only nodes that
have these attributes set (see
ClusterNode.attribute(String) and
IgniteConfiguration.getUserAttributes() methods). |
int |
JobStealingCollisionSpiMBean.getTotalStolenJobsNumber()
Gets total number of stolen jobs.
|
int |
JobStealingCollisionSpiMBean.getWaitJobsThreshold()
Gets job count threshold at which this node will
start stealing jobs from other nodes.
|
boolean |
JobStealingCollisionSpiMBean.isStealingEnabled()
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
|
void |
JobStealingCollisionSpiMBean.setActiveJobsThreshold(int activeJobsTreshold)
Sets number of jobs that can be executed in parallel.
|
void |
JobStealingCollisionSpiMBean.setMaximumStealingAttempts(int maximumStealingAttempts)
Gets maximum number of attempts to steal job by another node.
|
void |
JobStealingCollisionSpiMBean.setMessageExpireTime(long msgExpireTime)
Message expire time configuration parameter.
|
void |
JobStealingCollisionSpiMBean.setStealingEnabled(boolean stealingEnabled)
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
|
void |
JobStealingCollisionSpiMBean.setWaitJobsThreshold(int waitJobsThreshold)
Sets job count threshold at which this node will
start stealing jobs from other nodes.
|
Modifier and Type | Interface and Description |
---|---|
interface |
PriorityQueueCollisionSpiMBean
Management bean that provides access to the priority queue collision SPI configuration.
|
Modifier and Type | Method and Description |
---|---|
int |
PriorityQueueCollisionSpiMBean.getCurrentActiveJobsNumber()
Gets current number of jobs that are active, i.e.
|
int |
PriorityQueueCollisionSpiMBean.getCurrentHeldJobsNumber()
Gets number of currently
'held' jobs. |
int |
PriorityQueueCollisionSpiMBean.getCurrentRunningJobsNumber() |
int |
PriorityQueueCollisionSpiMBean.getCurrentWaitJobsNumber()
Gets current number of jobs that wait for the execution.
|
int |
PriorityQueueCollisionSpiMBean.getDefaultPriority()
Gets default priority to use if a job does not have priority attribute
set.
|
String |
PriorityQueueCollisionSpiMBean.getJobPriorityAttributeKey()
Gets key name of job priority attribute.
|
int |
PriorityQueueCollisionSpiMBean.getParallelJobsNumber()
Gets number of jobs that can be executed in parallel.
|
String |
PriorityQueueCollisionSpiMBean.getPriorityAttributeKey()
Gets key name of task priority attribute.
|
int |
PriorityQueueCollisionSpiMBean.getStarvationIncrement()
Gets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
|
int |
PriorityQueueCollisionSpiMBean.getWaitingJobsNumber()
Maximum number of jobs that are allowed to wait in waiting queue.
|
boolean |
PriorityQueueCollisionSpiMBean.isStarvationPreventionEnabled()
Gets flag indicating whether job starvation prevention is enabled.
|
void |
PriorityQueueCollisionSpiMBean.setDefaultPriority(int priority)
Sets default priority to use if a job does not have priority attribute set.
|
void |
PriorityQueueCollisionSpiMBean.setParallelJobsNumber(int num)
Sets number of jobs that can be executed in parallel.
|
void |
PriorityQueueCollisionSpiMBean.setStarvationIncrement(int increment)
Sets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
|
void |
PriorityQueueCollisionSpiMBean.setStarvationPreventionEnabled(boolean preventStarvation)
Sets flag indicating whether job starvation prevention is enabled.
|
void |
PriorityQueueCollisionSpiMBean.setWaitingJobsNumber(int num)
Maximum number of jobs that are allowed to wait in waiting queue.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TcpCommunicationSpiMBean
MBean provide access to TCP-based communication SPI.
|
Modifier and Type | Method and Description |
---|---|
int |
TcpCommunicationSpiMBean.getAckSendThreshold()
Gets number of received messages per connection to node after which acknowledgment message is sent.
|
long |
TcpCommunicationSpiMBean.getConnectionBufferFlushFrequency()
Gets connection buffer flush frequency.
|
int |
TcpCommunicationSpiMBean.getConnectionBufferSize()
Gets connection buffer size.
|
long |
TcpCommunicationSpiMBean.getConnectTimeout()
Gets connect timeout used when establishing connection
with remote nodes.
|
long |
TcpCommunicationSpiMBean.getIdleConnectionTimeout()
Gets maximum idle connection time upon which idle connections
will be closed.
|
String |
TcpCommunicationSpiMBean.getLocalAddress()
Gets local host address for socket binding.
|
int |
TcpCommunicationSpiMBean.getLocalPort()
Gets local port for socket binding.
|
int |
TcpCommunicationSpiMBean.getLocalPortRange()
Gets maximum number of local ports tried if all previously
tried ports are occupied.
|
long |
TcpCommunicationSpiMBean.getMaxConnectTimeout()
Gets maximum connect timeout.
|
int |
TcpCommunicationSpiMBean.getMessageQueueLimit()
Gets message queue limit for incoming and outgoing messages.
|
int |
TcpCommunicationSpiMBean.getMinimumBufferedMessageCount()
Gets the minimum number of messages for this SPI, that are buffered
prior to sending.
|
int |
TcpCommunicationSpiMBean.getOutboundMessagesQueueSize()
Gets outbound messages queue size.
|
long |
TcpCommunicationSpiMBean.getReceivedBytesCount()
Gets received bytes count.
|
int |
TcpCommunicationSpiMBean.getReceivedMessagesCount()
Gets received messages count.
|
int |
TcpCommunicationSpiMBean.getReconnectCount()
Gets maximum number of reconnect attempts used when establishing connection
with remote nodes.
|
int |
TcpCommunicationSpiMBean.getSelectorsCount()
Gets count of selectors used in TCP server.
|
long |
TcpCommunicationSpiMBean.getSentBytesCount()
Gets sent bytes count.
|
int |
TcpCommunicationSpiMBean.getSentMessagesCount()
Gets sent messages count.
|
int |
TcpCommunicationSpiMBean.getSharedMemoryPort()
Gets local port for shared memory communication.
|
int |
TcpCommunicationSpiMBean.getSocketReceiveBuffer()
Gets receive buffer size for sockets created or accepted by this SPI.
|
int |
TcpCommunicationSpiMBean.getSocketSendBuffer()
Gets send buffer size for sockets created or accepted by this SPI.
|
long |
TcpCommunicationSpiMBean.getSocketWriteTimeout()
Gets socket write timeout for TCP connections.
|
int |
TcpCommunicationSpiMBean.getUnacknowledgedMessagesBufferSize()
Gets maximum number of stored unacknowledged messages per connection to node.
|
boolean |
TcpCommunicationSpiMBean.isDirectBuffer()
Gets flag that indicates whether direct or heap allocated buffer is used.
|
boolean |
TcpCommunicationSpiMBean.isDirectSendBuffer()
Gets flag defining whether direct send buffer should be used.
|
boolean |
TcpCommunicationSpiMBean.isTcpNoDelay()
Gets value for
TCP_NODELAY socket option. |
void |
TcpCommunicationSpiMBean.setConnectionBufferFlushFrequency(long connBufFlushFreq)
Sets connection buffer flush frequency.
|
Modifier and Type | Interface and Description |
---|---|
interface |
LocalDeploymentSpiMBean
Management MBean for
LocalDeploymentSpi SPI. |
Modifier and Type | Interface and Description |
---|---|
interface |
UriDeploymentSpiMBean
Management bean for
UriDeploymentSpi . |
Modifier and Type | Method and Description |
---|---|
String |
UriDeploymentSpiMBean.getTemporaryDirectoryPath()
Gets temporary directory path.
|
List<String> |
UriDeploymentSpiMBean.getUriList()
Gets list of URIs that are processed by SPI.
|
boolean |
UriDeploymentSpiMBean.isCheckMd5()
Indicates if this SPI should check new deployment units md5 for redundancy.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoverySpiMBean.dumpDebugInfo()
Dumps debug info using configured logger.
|
long |
TcpDiscoverySpiMBean.getAckTimeout()
Gets message acknowledgement timeout.
|
long |
TcpDiscoverySpiMBean.getAvgMessageProcessingTime()
Gets avg message processing time.
|
UUID |
TcpDiscoverySpiMBean.getCoordinator()
Gets current coordinator.
|
long |
TcpDiscoverySpiMBean.getCoordinatorSinceTimestamp()
Gets time local node has been coordinator since.
|
long |
TcpDiscoverySpiMBean.getHeartbeatFrequency()
Gets delay between heartbeat messages sent by coordinator.
|
long |
TcpDiscoverySpiMBean.getIpFinderCleanFrequency()
Gets IP finder clean frequency.
|
String |
TcpDiscoverySpiMBean.getIpFinderFormatted()
Gets
TcpDiscoveryIpFinder (string representation). |
long |
TcpDiscoverySpiMBean.getJoinTimeout()
Gets join timeout.
|
int |
TcpDiscoverySpiMBean.getLocalPort()
Gets local TCP port SPI listens to.
|
int |
TcpDiscoverySpiMBean.getLocalPortRange()
Gets local TCP port range.
|
long |
TcpDiscoverySpiMBean.getMaxAckTimeout()
Gets maximum message acknowledgement timeout.
|
long |
TcpDiscoverySpiMBean.getMaxMessageProcessingTime()
Gets max message processing time.
|
int |
TcpDiscoverySpiMBean.getMaxMissedClientHeartbeats()
Gets max heartbeats count node can miss without failing client node.
|
int |
TcpDiscoverySpiMBean.getMaxMissedHeartbeats()
Gets max heartbeats count node can miss without initiating status check.
|
int |
TcpDiscoverySpiMBean.getMessageWorkerQueueSize()
Gets message worker queue current size.
|
long |
TcpDiscoverySpiMBean.getNetworkTimeout()
Gets network timeout.
|
long |
TcpDiscoverySpiMBean.getNodesFailed()
Gets failed nodes count.
|
long |
TcpDiscoverySpiMBean.getNodesJoined()
Gets joined nodes count.
|
long |
TcpDiscoverySpiMBean.getNodesLeft()
Gets left nodes count.
|
long |
TcpDiscoverySpiMBean.getPendingMessagesDiscarded()
Gets pending messages discarded count.
|
long |
TcpDiscoverySpiMBean.getPendingMessagesRegistered()
Gets pending messages registered count.
|
Map<String,Integer> |
TcpDiscoverySpiMBean.getProcessedMessages()
Gets processed messages counts (grouped by type).
|
Map<String,Integer> |
TcpDiscoverySpiMBean.getReceivedMessages()
Gets received messages counts (grouped by type).
|
int |
TcpDiscoverySpiMBean.getReconnectCount()
Gets number of connection attempts.
|
long |
TcpDiscoverySpiMBean.getSocketTimeout()
Gets socket timeout.
|
String |
TcpDiscoverySpiMBean.getSpiState()
Gets current SPI state.
|
long |
TcpDiscoverySpiMBean.getStatisticsPrintFrequency()
Gets statistics print frequency.
|
int |
TcpDiscoverySpiMBean.getThreadPriority()
Gets thread priority.
|
int |
TcpDiscoverySpiMBean.getTotalProcessedMessages()
Gets total processed messages count.
|
int |
TcpDiscoverySpiMBean.getTotalReceivedMessages()
Gets total received messages count.
|
boolean |
TcpDiscoverySpiMBean.isClientMode()
Whether or not discovery is started in client mode.
|
Modifier and Type | Interface and Description |
---|---|
interface |
MemoryEventStorageSpiMBean
Management bean for
MemoryEventStorageSpi . |
Modifier and Type | Method and Description |
---|---|
void |
MemoryEventStorageSpiMBean.clearAll()
Removes all events from the event queue.
|
long |
MemoryEventStorageSpiMBean.getExpireAgeMs()
Gets event time-to-live value.
|
long |
MemoryEventStorageSpiMBean.getExpireCount()
Gets maximum event queue size.
|
long |
MemoryEventStorageSpiMBean.getQueueSize()
Gets current queue size of the event queue.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AlwaysFailoverSpiMBean
Management bean for
AlwaysFailoverSpi . |
Modifier and Type | Method and Description |
---|---|
int |
AlwaysFailoverSpiMBean.getMaximumFailoverAttempts()
Gets maximum number of attempts to execute a failed job on another node.
|
int |
AlwaysFailoverSpiMBean.getTotalFailoverJobsCount()
Get total number of jobs that were failed over.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JobStealingFailoverSpiMBean
Management bean for
JobStealingFailoverSpi . |
Modifier and Type | Method and Description |
---|---|
int |
JobStealingFailoverSpiMBean.getMaximumFailoverAttempts()
Gets maximum number of attempts to execute a failed job on another node.
|
int |
JobStealingFailoverSpiMBean.getTotalFailedOverJobsCount()
Get total number of jobs that were failed over including stolen ones.
|
int |
JobStealingFailoverSpiMBean.getTotalStolenJobsCount()
Get total number of jobs that were stolen.
|
Modifier and Type | Interface and Description |
---|---|
interface |
NeverFailoverSpiMBean
Management bean for
NeverFailoverSpi . |
Modifier and Type | Interface and Description |
---|---|
interface |
AdaptiveLoadBalancingSpiMBean
Management MBean for
AdaptiveLoadBalancingSpi SPI. |
Modifier and Type | Method and Description |
---|---|
String |
AdaptiveLoadBalancingSpiMBean.getLoadProbeFormatted()
Gets text description of current load probing implementation used.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RoundRobinLoadBalancingSpiMBean
Management bean for
RoundRobinLoadBalancingSpi SPI. |
Modifier and Type | Method and Description |
---|---|
boolean |
RoundRobinLoadBalancingSpiMBean.isPerTask()
Configuration parameter indicating whether a new round robin order should be
created for every task.
|
Modifier and Type | Interface and Description |
---|---|
interface |
WeightedRandomLoadBalancingSpiMBean
Management MBean for
WeightedRandomLoadBalancingSpi SPI. |
Modifier and Type | Method and Description |
---|---|
int |
WeightedRandomLoadBalancingSpiMBean.getNodeWeight()
Gets weight of this node.
|
boolean |
WeightedRandomLoadBalancingSpiMBean.isUseWeights()
Checks whether node weights are considered when doing
random load balancing.
|
Modifier and Type | Interface and Description |
---|---|
interface |
FileSwapSpaceSpiMBean
Management bean for
FileSwapSpaceSpi . |
Modifier and Type | Method and Description |
---|---|
String |
FileSwapSpaceSpiMBean.getBaseDirectory()
Gets base directory.
|
float |
FileSwapSpaceSpiMBean.getMaximumSparsity()
Gets maximum sparsity.
|
int |
FileSwapSpaceSpiMBean.getMaxWriteQueueSize()
Gets max write queue size in bytes.
|
int |
FileSwapSpaceSpiMBean.getReadStripesNumber()
Gets read pool size.
|
int |
FileSwapSpaceSpiMBean.getWriteBufferSize()
Gets write buffer size in bytes.
|
Follow @ApacheIgnite
Ignite Fabric : ver. 1.2.0-incubating Release Date : June 16 2015