Package | Description |
---|---|
org.apache.ignite |
Contains entry-point Ignite & HPC APIs.
|
org.apache.ignite.spi.deployment.local |
Contains default local deployment SPI implementation.
|
Modifier and Type | Field and Description |
---|---|
static String |
IgniteSystemProperties.CHECKPOINT_PARALLEL_SORT_THRESHOLD
Starting from this number of dirty pages in checkpoint, array will be sorted with
Arrays.parallelSort(Comparable[]) in case of CheckpointWriteOrder.SEQUENTIAL . |
static String |
IgniteSystemProperties.CLIENT_THROTTLE_RECONNECT_RESET_TIMEOUT_INTERVAL
Time interval that indicates that client reconnect throttle must be reset to zero. 2 minutes by default.
|
static String |
IgniteSystemProperties.GRIDGAIN_UPDATE_URL
Url of updates service.
|
static String |
IgniteSystemProperties.IGNITE_AFFINITY_BACKUPS_THRESHOLD
Size threshold to allocate and retain additional HashMap to improve contains()
which leads to extra memory consumption.
|
static String |
IgniteSystemProperties.IGNITE_AFFINITY_HISTORY_SIZE
Maximum size for affinity assignment history.
|
static String |
IgniteSystemProperties.IGNITE_ALLOW_ATOMIC_OPS_IN_TX
Flag indicating whether atomic operations allowed to be used inside transactions.
|
static String |
IgniteSystemProperties.IGNITE_ALLOW_DML_INSIDE_TRANSACTION
When set to
true , Ignite will allow execute DML operation (MERGE|INSERT|UPDATE|DELETE)
within transaction for non MVCC mode. |
static String |
IgniteSystemProperties.IGNITE_ALLOW_START_CACHES_IN_PARALLEL
Enables start caches in parallel.
|
static String |
IgniteSystemProperties.IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE
Deprecated.
No longer used.
|
static String |
IgniteSystemProperties.IGNITE_ATOMIC_CACHE_QUEUE_RETRY_TIMEOUT
Atomic cache deferred update timeout.
|
static String |
IgniteSystemProperties.IGNITE_ATOMIC_DEFERRED_ACK_BUFFER_SIZE
Atomic cache deferred update response buffer size.
|
static String |
IgniteSystemProperties.IGNITE_ATOMIC_DEFERRED_ACK_TIMEOUT
Atomic cache deferred update timeout.
|
static String |
IgniteSystemProperties.IGNITE_BASELINE_AUTO_ADJUST_LOG_INTERVAL
Interval between logging of time of next auto-adjust.
|
static String |
IgniteSystemProperties.IGNITE_BINARY_DONT_WRAP_TREE_STRUCTURES
Deprecated.
Should be removed in Apache Ignite 2.0.
|
static String |
IgniteSystemProperties.IGNITE_BINARY_MARSHALLER_USE_STRING_SERIALIZATION_VER_2
Manages type of serialization mechanism for
String that is marshalled/unmarshalled by BinaryMarshaller. |
static String |
IgniteSystemProperties.IGNITE_BINARY_SORT_OBJECT_FIELDS
When set to
true fields are written by BinaryMarshaller in sorted order. |
static String |
IgniteSystemProperties.IGNITE_BPLUS_TREE_LOCK_RETRIES
Number of repetitions to capture a lock in the B+Tree.
|
static String |
IgniteSystemProperties.IGNITE_CACHE_CLIENT
Property controlling default behavior of cache client flag.
|
static String |
IgniteSystemProperties.IGNITE_CACHE_KEY_VALIDATION_DISABLED
Deprecated.
Since 2.7.26. Obsolete because of common use of binary marshaller.
|
static String |
IgniteSystemProperties.IGNITE_CACHE_REMOVED_ENTRIES_TTL
Deprecated.
No longer used.
|
static String |
IgniteSystemProperties.IGNITE_CACHE_RETRIES_COUNT
Number of cache operation retries in case of topology exceptions.
|
static String |
IgniteSystemProperties.IGNITE_CACHE_START_SIZE
Cache start size for on-heap maps.
|
static String |
IgniteSystemProperties.IGNITE_CHECK_COMMUNICATION_HANDSHAKE_MESSAGE_SENDER
Enables additional check that sender of communication handshake message corresponds to the node id
included in the message.
|
static String |
IgniteSystemProperties.IGNITE_CHECK_SENDER_NODE_SUBJECT
If the property is set, coincidence of client identifier and subject is required when security is enabled.
|
static String |
IgniteSystemProperties.IGNITE_CHECKPOINT_MAP_SNAPSHOT_THRESHOLD
Threshold of the checkpoint quantity since the last earliest checkpoint map snapshot.
|
static String |
IgniteSystemProperties.IGNITE_CHECKPOINT_READ_LOCK_TIMEOUT
Timeout for checkpoint read lock acquisition in milliseconds.
|
static String |
IgniteSystemProperties.IGNITE_CHECKPOINT_TRIGGER_ARCHIVE_SIZE_PERCENTAGE
Property for setup percentage of archive size for checkpoint trigger.
|
static String |
IgniteSystemProperties.IGNITE_CLIENT_CACHE_CHANGE_MESSAGE_TIMEOUT
When client cache is started or closed special discovery message is sent to notify cluster (for example this is
needed for
ClusterGroup.forCacheNodes(String) API. |
static String |
IgniteSystemProperties.IGNITE_CLUSTER_NAME
Ignite cluster name.
|
static String |
IgniteSystemProperties.IGNITE_COMPACTED_TOPOLOGY_HISTORY
Nodes will send messages with compacted topology history.
|
static String |
IgniteSystemProperties.IGNITE_CONFIG_URL
System property to hold optional configuration URL.
|
static String |
IgniteSystemProperties.IGNITE_CONFIGURATION_VIEW_PACKAGES
Comma separated packages list to expose in configuration view.
|
static String |
IgniteSystemProperties.IGNITE_CONSISTENT_ID_BY_HOST_WITHOUT_PORT
When set to
true , for consistent id will calculate by host name, without port, and you can use
only one node for host in cluster. |
static String |
IgniteSystemProperties.IGNITE_CONSOLE_APPENDER
If this property is set to
true (default) and Ignite is launched
in verbose mode (see IgniteSystemProperties.IGNITE_QUIET ) and no console appenders can be found
in configuration, then default console appender will be added. |
static String |
IgniteSystemProperties.IGNITE_DAEMON
Presence of this system property with value
true will make the grid
node start as a daemon node. |
static String |
IgniteSystemProperties.IGNITE_DATA_STORAGE_FOLDER_BY_CONSISTENT_ID
When set to
true , Data store folders are generated only by consistent id, and no consistent ID will be
set based on existing data store folders. |
static String |
IgniteSystemProperties.IGNITE_DATA_STREAMER_ALLOW_OVERWRITE |
static String |
IgniteSystemProperties.IGNITE_DATA_STREAMING_EXECUTOR_SERVICE_TASKS_STEALING_THRESHOLD
Tasks stealing will be started if tasks queue size per data-streamer thread exceeds this threshold.
|
static String |
IgniteSystemProperties.IGNITE_DEFAULT_DATA_STORAGE_PAGE_SIZE
Sets default
storage page size . |
static String |
IgniteSystemProperties.IGNITE_DEFAULT_DISK_PAGE_COMPRESSION
Sets default isk page compression.
|
static String |
IgniteSystemProperties.IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_BUFFER_SIZE
One phase commit deferred ack request buffer size.
|
static String |
IgniteSystemProperties.IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_TIMEOUT
One phase commit deferred ack request timeout.
|
static String |
IgniteSystemProperties.IGNITE_DEFRAGMENTATION_REGION_SIZE_PERCENTAGE
Defragmentation region size percentage of configured region size.
|
static String |
IgniteSystemProperties.IGNITE_DELAYED_REPLACED_PAGE_WRITE
When set to
true (default), pages are written to page store without holding segment lock (with delay). |
static String |
IgniteSystemProperties.IGNITE_DEP_MODE_OVERRIDE
System property to override deployment mode configuration parameter.
|
static String |
IgniteSystemProperties.IGNITE_DEV_ONLY_LOGGING_DISABLED
When set to
true , warnings that are intended for development environments and not for production
(such as coding mistakes in code using Ignite) will not be logged. |
static String |
IgniteSystemProperties.IGNITE_DFLT_ALLOW_EMPTY_SYS_PERMISSIONS
If specified, enforces legacy behavior for system properties authorization when
SecurityPermissionSet.defaultAllowAll() is set to true: if user's system permission set is empty,
all system actions will be prohibited. |
static String |
IgniteSystemProperties.IGNITE_DIAGNOSTIC_ENABLED |
static String |
IgniteSystemProperties.IGNITE_DIAGNOSTIC_WARN_LIMIT
Maximum number of diagnostic warning messages per category, when waiting for PME.
|
static String |
IgniteSystemProperties.IGNITE_DIRECT_IO_ENABLED
When set to
true , direct IO may be enabled. |
static String |
IgniteSystemProperties.IGNITE_DISABLE_AFFINITY_MEMORY_OPTIMIZATION
Flag to disable memory optimization:
BitSets instead of HashSets to store partitions.
|
static String |
IgniteSystemProperties.IGNITE_DISABLE_GRP_STATE_LAZY_STORE
Disable group state lazy store.
|
static String |
IgniteSystemProperties.IGNITE_DISABLE_HOSTNAME_VERIFIER
System property to disable
HostnameVerifier for SSL connections. |
static String |
IgniteSystemProperties.IGNITE_DISABLE_MAINTENANCE_CLEAR_FOLDER_TASK |
static String |
IgniteSystemProperties.IGNITE_DISABLE_ONHEAP_CACHE
When set to
true , on-heap cache cannot be enabled - see
CacheConfiguration.setOnheapCacheEnabled(boolean) . |
static String |
IgniteSystemProperties.IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION
When property is set
false each next exchange will try to compare with previous. |
static String |
IgniteSystemProperties.IGNITE_DISABLE_SMART_DR_THROTTLING
Disables smart DR throttling.
|
static String |
IgniteSystemProperties.IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT
Disables cache interceptor triggering in case of conflicts.
|
static String |
IgniteSystemProperties.IGNITE_DISABLE_WAL_DURING_REBALANCING
When set to
false , WAL will not be automatically disabled during rebalancing if there is no partition in
OWNING state. |
static String |
IgniteSystemProperties.IGNITE_DISCO_FAILED_CLIENT_RECONNECT_DELAY
Defines reconnect delay in milliseconds for client node that was failed forcible.
|
static String |
IgniteSystemProperties.IGNITE_DISCOVERY_CLIENT_RECONNECT_HISTORY_SIZE
Maximum number of discovery message history used to support client reconnect.
|
static String |
IgniteSystemProperties.IGNITE_DISCOVERY_DISABLE_CACHE_METRICS_UPDATE
When set to
true , cache metrics are not included into the discovery metrics update message (in this
case message contains only cluster metrics). |
static String |
IgniteSystemProperties.IGNITE_DISCOVERY_HISTORY_SIZE
Maximum size for discovery messages history.
|
static String |
IgniteSystemProperties.IGNITE_DISCOVERY_METRICS_QNT_WARN
Logging a warning message when metrics quantity exceeded a specified number.
|
static String |
IgniteSystemProperties.IGNITE_DUMP_PAGE_LOCK_ON_FAILURE
Enables threads locks dumping on critical node failure.
|
static String |
IgniteSystemProperties.IGNITE_DUMP_PERSISTENCE_FILES_ON_DATA_CORRUPTION
Dumps latest WAL segments and related index and partition files on data corruption error.
|
static String |
IgniteSystemProperties.IGNITE_DUMP_THREADS_ON_FAILURE
Enables threads dumping on critical node failure.
|
static String |
IgniteSystemProperties.IGNITE_DUMP_THREADS_ON_FAILURE_THROTTLING_TIMEOUT
Throttling time out for thread dump generation during failure handling.
|
static String |
IgniteSystemProperties.IGNITE_DUMP_TX_COLLISIONS_INTERVAL
When above zero, prints tx key collisions once per interval.
|
static String |
IgniteSystemProperties.IGNITE_ENABLE_EXPERIMENTAL_COMMAND
System property to enable experimental commands in control.sh script.
|
static String |
IgniteSystemProperties.IGNITE_ENABLE_EXTRA_INDEX_REBUILD_LOGGING
Enables extended logging of indexes create/rebuild process.
|
static String |
IgniteSystemProperties.IGNITE_ENABLE_FORCIBLE_NODE_KILL
If this property is set, a node will forcible fail a remote node when it fails to establish a communication
connection.
|
static String |
IgniteSystemProperties.IGNITE_ENABLE_HASH_JOIN
Enable hash join (create hash index on the fly) for query optimizer.
|
static String |
IgniteSystemProperties.IGNITE_ENABLE_SUBQUERY_REWRITE_OPTIMIZATION
Enables subquery rewriting optimization.
|
static String |
IgniteSystemProperties.IGNITE_EVENT_DRIVEN_SERVICE_PROCESSOR_ENABLED
Manages the type of the implementation of the service processor (implementation of the
IgniteServices ). |
static String |
IgniteSystemProperties.IGNITE_EVICTION_PERMITS
Deprecated.
|
static String |
IgniteSystemProperties.IGNITE_EXCEPTION_REGISTRY_MAX_SIZE
Property controlling size of buffer holding last exception.
|
static String |
IgniteSystemProperties.IGNITE_EXCHANGE_HISTORY_SIZE
Maximum size for exchange history.
|
static String |
IgniteSystemProperties.IGNITE_EXCHANGE_MERGE_DELAY |
static String |
IgniteSystemProperties.IGNITE_EXECUTE_DURABLE_BACKGROUND_TASKS_ON_NODE_START_OR_ACTIVATE
There can be background tasks that can be interrupted due to node stop, node fail, or cluster deactivation,
but need to be completed, so they start after node start or cluster activation.
|
static String |
IgniteSystemProperties.IGNITE_FAIL_NODE_ON_UNRECOVERABLE_PARTITION_INCONSISTENCY
Flag to enable triggering failure handler for node if unrecoverable partition inconsistency is
discovered during partition update counters exchange.
|
static String |
IgniteSystemProperties.IGNITE_FAILURE_HANDLER_RESERVE_BUFFER_SIZE
Amount of memory reserved in the heap at node start, which can be dropped to increase the chances of success when
handling OutOfMemoryError.
|
static String |
IgniteSystemProperties.IGNITE_FORCE_MVCC_MODE_IN_TESTS
For test purposes only.
|
static String |
IgniteSystemProperties.IGNITE_GLOBAL_METASTORAGE_HISTORY_MAX_BYTES
Maximum amount of bytes that can be stored in history of
DistributedMetaStorage updates. |
static String |
IgniteSystemProperties.IGNITE_GRID_CLIENT_LOG_ENABLED
If this property is set to
true enable logging in GridClient . |
static String |
IgniteSystemProperties.IGNITE_H2_DEBUG_CONSOLE
Deprecated.
Since 2.8. H2 console is no longer supported.
|
static String |
IgniteSystemProperties.IGNITE_H2_DEBUG_CONSOLE_PORT
Deprecated.
Since 2.8. H2 console is no longer supported.
|
static String |
IgniteSystemProperties.IGNITE_H2_INDEXING_CACHE_CLEANUP_PERIOD
System property to specify period in milliseconds between calls of the SQL statements cache cleanup task.
|
static String |
IgniteSystemProperties.IGNITE_H2_INDEXING_CACHE_THREAD_USAGE_TIMEOUT
System property to specify timeout in milliseconds after which thread's SQL statements cache is cleared by
cleanup task if the thread does not perform any query.
|
static String |
IgniteSystemProperties.IGNITE_H2_LOCAL_RESULT_FACTORY
Defines factory class for H2 LocalResult (see org.gridgain.internal.h2.result.LocalResult).
|
static String |
IgniteSystemProperties.IGNITE_HASH_JOIN_MAX_TABLE_SIZE
Maximum size of table (rows count) when temporary hash index can be built on fly.
|
static String |
IgniteSystemProperties.IGNITE_HOME
Defines Ignite installation folder.
|
static String |
IgniteSystemProperties.IGNITE_IGNORE_LOCAL_HOST_NAME
System property to ignore reading hostname of the local address.
|
static String |
IgniteSystemProperties.IGNITE_INDEX_COST_FUNCTION
Choose the index cost function.
|
static String |
IgniteSystemProperties.IGNITE_INDEX_REBUILD_BATCH_SIZE
Count of rows, being processed within a single checkpoint lock when indexes are rebuilt.
|
static String |
IgniteSystemProperties.IGNITE_INDEXING_DISCOVERY_HISTORY_SIZE
Indexing discovery history size.
|
static String |
IgniteSystemProperties.IGNITE_IO_BALANCE_PERIOD |
static String |
IgniteSystemProperties.IGNITE_IO_DUMP_ON_TIMEOUT |
static String |
IgniteSystemProperties.IGNITE_IPC_SHMEM_SPACE_DEBUG
If this property is set to
true then shared memory space native debug will be enabled. |
static String |
IgniteSystemProperties.IGNITE_JCACHE_DEFAULT_ISOLATED
Property controlling whether CacheManager will start grid with isolated IP finder when default URL
is passed in.
|
static String |
IgniteSystemProperties.IGNITE_JDBC_DRIVER_CURSOR_REMOVE_DELAY
JDBC driver cursor remove delay.
|
static String |
IgniteSystemProperties.IGNITE_JETTY_HOST
This property allows to override Jetty host for REST processor.
|
static String |
IgniteSystemProperties.IGNITE_JETTY_LOG_NO_OVERRIDE
This property does not allow Ignite to override Jetty log configuration for REST processor.
|
static String |
IgniteSystemProperties.IGNITE_JETTY_PORT
This property allows to override Jetty local port for REST processor.
|
static String |
IgniteSystemProperties.IGNITE_JOBS_HISTORY_SIZE
System property to override default job processor maps sizes for finished jobs and
cancellation requests.
|
static String |
IgniteSystemProperties.IGNITE_JOBS_METRICS_CONCURRENCY_LEVEL
Deprecated.
Use
GridMetricManager instead. |
static String |
IgniteSystemProperties.IGNITE_JVM_PAUSE_DETECTOR_DISABLED
Ignite JVM pause detector disabled.
|
static String |
IgniteSystemProperties.IGNITE_JVM_PAUSE_DETECTOR_LAST_EVENTS_COUNT
Ignite JVM pause detector last events count.
|
static String |
IgniteSystemProperties.IGNITE_JVM_PAUSE_DETECTOR_PRECISION
Ignite JVM pause detector precision.
|
static String |
IgniteSystemProperties.IGNITE_JVM_PAUSE_DETECTOR_THRESHOLD
Ignite JVM pause detector threshold.
|
static String |
IgniteSystemProperties.IGNITE_KEEP_STATIC_CACHE_CONFIGURATION
Keep static cache configuration even if stored cache data differs from the static config.
|
static String |
IgniteSystemProperties.IGNITE_KEEP_UNCLEARED_EXCHANGE_FUTURES_LIMIT
Defines how many exchange futures are kept uncleared in the queue.
|
static String |
IgniteSystemProperties.IGNITE_LOADED_PAGES_BACKWARD_SHIFT_MAP
When set to
false , loaded pages implementation is switched to previous version of implementation,
FullPageIdTable. |
static String |
IgniteSystemProperties.IGNITE_LOCAL_HOST
The system property sets a system-wide local IP address or hostname to be used by Ignite networking components.
|
static String |
IgniteSystemProperties.IGNITE_LOCAL_STORE_KEEPS_PRIMARY_ONLY
Indicating whether local store keeps primary only.
|
static String |
IgniteSystemProperties.IGNITE_LOG_CLASSPATH_CONTENT_ON_STARTUP
Scan the classpath on startup and log all the files containing in it.
|
static String |
IgniteSystemProperties.IGNITE_LOG_DIR
Environment variable to override logging directory that has been set in logger configuration.
|
static String |
IgniteSystemProperties.IGNITE_LOG_GRID_NAME
Deprecated.
|
static String |
IgniteSystemProperties.IGNITE_LOG_INSTANCE_NAME
If this system property is present the Ignite will include instance name into verbose log.
|
static String |
IgniteSystemProperties.IGNITE_LOG_THROTTLE_CAPACITY
Max amount of remembered errors for
GridLogThrottle . |
static String |
IgniteSystemProperties.IGNITE_LONG_LONG_HASH_MAP_LOAD_FACTOR
Long-long offheap map load factor.
|
static String |
IgniteSystemProperties.IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT
Cache operations that take more time than value of this property will be output to log.
|
static String |
IgniteSystemProperties.IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT_LIMIT
Upper time limit between long running/hanging operations debug dumps.
|
static String |
IgniteSystemProperties.IGNITE_LONG_TRANSACTION_TIME_DUMP_THRESHOLD
Threshold timeout for long transactions, if transaction exceeds it, it will be dumped in log with
information about how much time did it spent in system time (time while aquiring locks, preparing,
commiting, etc) and user time (time when client node runs some code while holding transaction and not
waiting it).
|
static String |
IgniteSystemProperties.IGNITE_MAINTENANCE_AUTO_SHUTDOWN_AFTER_RECOVERY
Node in maintenance mode will automatically shut down after all active maintenance would be completed.
|
static String |
IgniteSystemProperties.IGNITE_MAINTENANCE_MODE_EXIT_CODE
Node in maintenance mode will shut down with specified JVM exit code.
|
static String |
IgniteSystemProperties.IGNITE_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE
System property to specify per thread binary allocator chunk pool size.
|
static String |
IgniteSystemProperties.IGNITE_MARSHAL_BUFFERS_RECHECK
System property to specify how often in milliseconds marshal buffers
should be rechecked and potentially trimmed.
|
static String |
IgniteSystemProperties.IGNITE_MARSHALLER_BLACKLIST
Defines path to the file that contains list of classes disallowed to safe deserialization.
|
static String |
IgniteSystemProperties.IGNITE_MARSHALLER_WHITELIST
Defines path to the file that contains list of classes allowed to safe deserialization.
|
static String |
IgniteSystemProperties.IGNITE_MASTER_KEY_NAME_TO_CHANGE_BEFORE_STARTUP
The master key name that the node will use during the recovery.
|
static String |
IgniteSystemProperties.IGNITE_MAX_COMPLETED_TX_COUNT
Property controlling size of buffer holding completed transaction versions.
|
static String |
IgniteSystemProperties.IGNITE_MAX_INDEX_PAYLOAD_SIZE
System property to specify maximum payload size in bytes for
H2TreeIndex . |
static String |
IgniteSystemProperties.IGNITE_MAX_NESTED_LISTENER_CALLS
Maximum number of nested listener calls before listener notification becomes asynchronous.
|
static String |
IgniteSystemProperties.IGNITE_MBEAN_APPEND_CLASS_LOADER_ID
If this property is set to
true then Ignite will append
hash code of class loader to MXBean name. |
static String |
IgniteSystemProperties.IGNITE_MBEAN_APPEND_JVM_ID
If this property is set to
true then Ignite will append
hash code of Ignite class as hex string and append
JVM name returned by RuntimeMXBean.getName() . |
static String |
IgniteSystemProperties.IGNITE_MBEANS_DISABLED
If property is set to
true , then Ignite will disable MBeans registration. |
static String |
IgniteSystemProperties.IGNITE_MEMORY_PER_BYTE_COPY_THRESHOLD
When unsafe memory copy if performed below this threshold, Ignite will do it on per-byte basis instead of
calling to Unsafe.copyMemory().
|
static String |
IgniteSystemProperties.IGNITE_MEMORY_UNALIGNED_ACCESS
Whether Ignite can access unaligned memory addresses.
|
static String |
IgniteSystemProperties.IGNITE_MIN_AFFINITY_HISTORY_SIZE
Minimum size for affinity assignment history.
|
static String |
IgniteSystemProperties.IGNITE_MIN_BUFFERED_COMMUNICATION_MSG_CNT
Deprecated.
Not used anymore.
|
static String |
IgniteSystemProperties.IGNITE_MVCC_TX_SIZE_CACHING_THRESHOLD
Maximum number for cached MVCC transaction updates.
|
static String |
IgniteSystemProperties.IGNITE_NEAR_GET_MAX_REMAPS
This property defines the maximum number of attempts to remap near get to the same
primary node.
|
static String |
IgniteSystemProperties.IGNITE_NIO_RECOVERY_DESCRIPTOR_RESERVATION_TIMEOUT
Sets timeout for TCP client recovery descriptor reservation.
|
static String |
IgniteSystemProperties.IGNITE_NO_ASCII
If this system property is present (any value) - no ASCII logo will
be printed.
|
static String |
IgniteSystemProperties.IGNITE_NO_DISCO_ORDER
Name of the system property to disable requirement for proper node ordering
by discovery SPI.
|
static String |
IgniteSystemProperties.IGNITE_NO_SELECTOR_OPTS
If set to
true , then default selected keys set is used inside
GridNioServer which lead to some extra garbage generation when
processing selected keys. |
static String |
IgniteSystemProperties.IGNITE_NO_SHUTDOWN_HOOK
If this system property is set to
true - no shutdown hook will be set. |
static String |
IgniteSystemProperties.IGNITE_NODE_IDS_HISTORY_SIZE
Maximum size of history of server nodes (server node IDs) that ever joined to current topology.
|
static String |
IgniteSystemProperties.IGNITE_OFFHEAP_LOCK_CONCURRENCY_LEVEL
Ignite page memory concurrency level.
|
static String |
IgniteSystemProperties.IGNITE_OFFHEAP_SAFE_RELEASE
Flag that will force Ignite to fill memory block with some recognisable pattern right before
this memory block is released.
|
static String |
IgniteSystemProperties.IGNITE_OPTIMIZED_MARSHALLER_USE_DEFAULT_SUID
|
static String |
IgniteSystemProperties.IGNITE_OVERRIDE_CONSISTENT_ID
System property to specify consistent id of Ignite node.
|
static String |
IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP
System property to override multicast group taken from configuration.
|
static String |
IgniteSystemProperties.IGNITE_OVERRIDE_WRITE_THROTTLING_ENABLED
If this property is set,
DataStorageConfiguration.isWriteThrottlingEnabled()
will be overridden to true regardless the initial value in the configuration. |
static String |
IgniteSystemProperties.IGNITE_PAGE_LOCK_TRACKER_CAPACITY
Capacity in pages for storing in page lock tracker strucuture.
|
static String |
IgniteSystemProperties.IGNITE_PAGE_LOCK_TRACKER_CHECK_INTERVAL
Page lock tracker thread for checking hangs threads interval.
|
static String |
IgniteSystemProperties.IGNITE_PAGE_LOCK_TRACKER_TYPE
Page lock tracker type
|
static String |
IgniteSystemProperties.IGNITE_PAGES_LIST_DISABLE_ONHEAP_CACHING |
static String |
IgniteSystemProperties.IGNITE_PART_DISTRIBUTION_WARN_THRESHOLD
The threshold of uneven distribution above which partition distribution will be logged.
|
static String |
IgniteSystemProperties.IGNITE_PARTITION_RELEASE_FUTURE_DUMP_THRESHOLD
If a partition release future completion time during an exchange exceeds this threshold, the contents of
the future will be dumped to the log on exchange.
|
static String |
IgniteSystemProperties.IGNITE_PARTITION_RELEASE_FUTURE_WARN_LIMIT
This property specifies the maximum number of futures that are included into diagnostic message.
|
static String |
IgniteSystemProperties.IGNITE_PDS_MAX_CHECKPOINT_MEMORY_HISTORY_SIZE
Number of checkpoint history entries held in memory.
|
static String |
IgniteSystemProperties.IGNITE_PDS_PARTITION_DESTROY_CHECKPOINT_DELAY
Deprecated.
|
static String |
IgniteSystemProperties.IGNITE_PDS_SKIP_CRC
Skip CRC calculation flag.
|
static String |
IgniteSystemProperties.IGNITE_PDS_WAL_REBALANCE_THRESHOLD
Deprecated.
use Distributed MetaStorage property
GridCacheDatabaseSharedManager.HISTORICAL_REBALANCE_THRESHOLD_DMS_KEY . |
static String |
IgniteSystemProperties.IGNITE_PENDING_TX_TRACKER_ENABLED
System property to enable pending transaction tracker.
|
static String |
IgniteSystemProperties.IGNITE_PERFORMANCE_SUGGESTIONS_DISABLED
Flag indicating whether performance suggestions output on start should be disabled.
|
static String |
IgniteSystemProperties.IGNITE_PREFER_WAL_REBALANCE
Prefer historical rebalance if there's enough history regardless of all heuristics.
|
static String |
IgniteSystemProperties.IGNITE_PRELOAD_RESEND_TIMEOUT
System property to hold preload resend timeout for evicted partitions.
|
static String |
IgniteSystemProperties.IGNITE_PROG_NAME
Name of the system property defining name of command line program.
|
static String |
IgniteSystemProperties.IGNITE_QUIET
Set to either
true or false to enable or disable quiet mode
of Ignite. |
static String |
IgniteSystemProperties.IGNITE_READ_LOAD_BALANCING
Whenever read load balancing is enabled, that means 'get' requests will be distributed between primary and backup
nodes if it is possible and
CacheConfiguration.isReadFromBackup() is true . |
static String |
IgniteSystemProperties.IGNITE_REBALANCE_STATISTICS_TIME_INTERVAL
Deprecated.
Use
MetricsMxBean.configureHitRateMetric(String, long) instead. |
static String |
IgniteSystemProperties.IGNITE_REBALANCE_THROTTLE_OVERRIDE
Deprecated.
Use
IgniteConfiguration.getRebalanceThrottle() instead. |
static String |
IgniteSystemProperties.IGNITE_RECOVERY_SEMAPHORE_PERMITS
Limit the maximum number of objects in memory during the recovery procedure.
|
static String |
IgniteSystemProperties.IGNITE_RECOVERY_VERBOSE_LOGGING
Allows to log additional information about all restored partitions after binary and logical recovery phases.
|
static String |
IgniteSystemProperties.IGNITE_REFLECTION_CACHE_SIZE
System property to override default reflection cache size.
|
static String |
IgniteSystemProperties.IGNITE_REST_GETALL_AS_ARRAY
Deprecated.
Should be made default in Apache Ignite 3.0.
|
static String |
IgniteSystemProperties.IGNITE_REST_MAX_TASK_RESULTS
This property allows to override maximum count of task results stored on one node
in REST processor.
|
static String |
IgniteSystemProperties.IGNITE_REST_SECURITY_TOKEN_TIMEOUT
This property allow rewriting default (
300 ) REST session security token expire time (in seconds). |
static String |
IgniteSystemProperties.IGNITE_REST_SESSION_TIMEOUT
This property allow rewriting default (
30 ) REST session expire time (in seconds). |
static String |
IgniteSystemProperties.IGNITE_REST_START_ON_CLIENT
This property allows to override default behavior that rest processor
doesn't start on client node.
|
static String |
IgniteSystemProperties.IGNITE_RESTART_CODE
This property is used internally to pass an exit code to loader when
Ignite instance is being restarted.
|
static String |
IgniteSystemProperties.IGNITE_REUSE_MEMORY_ON_DEACTIVATE
Try reuse memory on deactivation.
|
static String |
IgniteSystemProperties.IGNITE_SECURITY_COMPATIBILITY_MODE
When set to
true , Ignite switches to compatibility mode with versions that don't
support service security permissions. |
static String |
IgniteSystemProperties.IGNITE_SECURITY_FOR_SYS_CACHE_ENABLED
If the property is set, client nodes should have explicitly rights to access to system cache.
|
static String |
IgniteSystemProperties.IGNITE_SENSITIVE_DATA_LOGGING
Setting to
"plain" enables writing sensitive information in toString() output. |
static String |
IgniteSystemProperties.IGNITE_SERVICES_SET_REMOTE_FILTER_ON_START
This property allows reducing the number of internal notifications of thick clients
when the cache-based implementation of the service framework is used.
|
static String |
IgniteSystemProperties.IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK
Property allowing to skip configuration consistency checks.
|
static String |
IgniteSystemProperties.IGNITE_SKIP_PARTITION_SIZE_VALIDATION
When set to
true , Ignite will skip partitions sizes check on partition validation after rebalance has finished. |
static String |
IgniteSystemProperties.IGNITE_SLOW_TX_WARN_TIMEOUT
Transactions that take more time, than value of this property, will be output to log
with warning level.
|
static String |
IgniteSystemProperties.IGNITE_SQL_ALLOW_KEY_VAL_UPDATES
Allow use composite _key, _val columns at the INSERT/UPDATE/MERGE statements.
|
static String |
IgniteSystemProperties.IGNITE_SQL_DISABLE_SYSTEM_VIEWS
Disable SQL system views.
|
static String |
IgniteSystemProperties.IGNITE_SQL_DISTINCT_RESULTS_USE_TREE_MAP
Use TreeMap instead of HashMap to hold distinct values.
|
static String |
IgniteSystemProperties.IGNITE_SQL_ENABLE_CONNECTION_MEMORY_QUOTA
Deprecated.
Possibility to modify query qouta is now managed
by security permission
SecurityPermission.SET_QUERY_MEMORY_QUOTA . |
static String |
IgniteSystemProperties.IGNITE_SQL_FILL_ABSENT_PK_WITH_DEFAULTS
Forcibly fills missing columns belonging to the primary key with nulls or default values if those have been specified.
|
static String |
IgniteSystemProperties.IGNITE_SQL_MAX_EXTRACTED_PARTS_FROM_BETWEEN
Maximum number of different partitions to be extracted from between expression within sql query.
|
static String |
IgniteSystemProperties.IGNITE_SQL_MEMORY_RESERVATION_BLOCK_SIZE
Defines default memory reservation block size.
|
static String |
IgniteSystemProperties.IGNITE_SQL_MERGE_TABLE_MAX_SIZE
Property controlling maximum number of SQL result rows which can be fetched into a merge table.
|
static String |
IgniteSystemProperties.IGNITE_SQL_MERGE_TABLE_PREFETCH_SIZE
Property controlling number of SQL result rows that will be fetched into a merge table at once before
applying binary search for the bounds.
|
static String |
IgniteSystemProperties.IGNITE_SQL_PARSER_DISABLE_H2_FALLBACK
Disable fallback to H2 SQL parser if the internal SQL parser fails to parse the statement.
|
static String |
IgniteSystemProperties.IGNITE_SQL_RETRY_TIMEOUT
SQL retry timeout.
|
static String |
IgniteSystemProperties.IGNITE_SQL_SYSTEM_SCHEMA_NAME_IGNITE
Enable backward compatible to use 'IGNITE' as SQL system schema.
|
static String |
IgniteSystemProperties.IGNITE_SQL_UUID_DDL_BYTE_FORMAT
Enable backward compatible handling of UUID through DDL.
|
static String |
IgniteSystemProperties.IGNITE_SSH_HOST
System property to hold SSH host for visor-started nodes.
|
static String |
IgniteSystemProperties.IGNITE_SSH_USER_NAME
System property to hold SSH user name for visor-started nodes.
|
static String |
IgniteSystemProperties.IGNITE_SSL_HANDSHAKE_TIMEOUT
SSL handshake timeout.
|
static String |
IgniteSystemProperties.IGNITE_SSL_UNWRAP_TIMEOUT
SSL unwrap timeout.
|
static String |
IgniteSystemProperties.IGNITE_START_CACHES_ON_JOIN |
static String |
IgniteSystemProperties.IGNITE_STARVATION_CHECK_INTERVAL
This system property defines interval in milliseconds in which Ignite will check
thread pool state for starvation.
|
static String |
IgniteSystemProperties.IGNITE_STREAM_TRANSFORMER_COMPATIBILITY_MODE
Manages backward compatibility of
StreamTransformer.from(CacheEntryProcessor) method. |
static String |
IgniteSystemProperties.IGNITE_STRICT_CONSISTENCY_CHECK
Enables strict mode to check not critical internal invariants.
|
static String |
IgniteSystemProperties.IGNITE_SUCCESS_FILE
Deprecated.
No longer used.
|
static String |
IgniteSystemProperties.IGNITE_SYSTEM_WORKER_BLOCKED_TIMEOUT
Maximum inactivity period for system worker in milliseconds.
|
static String |
IgniteSystemProperties.IGNITE_TCP_COMM_SET_ATTR_HOST_NAMES
Enables setting attribute value of
ATTR_HOST_NAMES when value getLocalHost is ip, for backward
compatibility. |
static String |
IgniteSystemProperties.IGNITE_TCP_DISCOVERY_ADDRESSES
Comma separated list of addresses in format "10.100.22.100:45000,10.100.22.101:45000".
|
static String |
IgniteSystemProperties.IGNITE_TEST_ENV
Set to true only during the junit tests.
|
static String |
IgniteSystemProperties.IGNITE_TEST_FEATURES_ENABLED
If property is set to
true , then test features will be enabled. |
static String |
IgniteSystemProperties.IGNITE_THREAD_DUMP_ON_EXCHANGE_TIMEOUT
If this property is set to
true then Ignite will log thread dump in case of partition exchange timeout. |
static String |
IgniteSystemProperties.IGNITE_THRESHOLD_WAIT_TIME_NEXT_WAL_SEGMENT
Threshold time (in millis) to print warning to log if waiting for next wal segment took longer than the threshold.
|
static String |
IgniteSystemProperties.IGNITE_THRESHOLD_WAL_ARCHIVE_SIZE_PERCENTAGE
Deprecated.
|
static String |
IgniteSystemProperties.IGNITE_THROTTLE_LOG_THRESHOLD
Threshold for throttling operations logging.
|
static String |
IgniteSystemProperties.IGNITE_TO_STRING_COLLECTION_LIMIT
Limit collection (map, array) elements number to output.
|
static String |
IgniteSystemProperties.IGNITE_TO_STRING_INCLUDE_SENSITIVE
Deprecated.
Use
IgniteSystemProperties.IGNITE_SENSITIVE_DATA_LOGGING instead. |
static String |
IgniteSystemProperties.IGNITE_TO_STRING_MAX_LENGTH
Maximum length for
toString() result. |
static String |
IgniteSystemProperties.IGNITE_TO_STRING_THROW_RUNTIME_EXCEPTION
Boolean flag indicating whether
GridToStringBuilder should throw RuntimeException
when building string representation of an object or should just print information about exception into the log
and proceed. |
static String |
IgniteSystemProperties.IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT
The coefficient for samples of completed transactions that will be dumped in log.
|
static String |
IgniteSystemProperties.IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_PER_SECOND_LIMIT
The limit of samples of completed transactions that will be dumped in log per second, if
IgniteSystemProperties.IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT is above 0.0 . |
static String |
IgniteSystemProperties.IGNITE_TROUBLESHOOTING_LOGGER
Setting this option to
true will enable troubleshooting logger. |
static String |
IgniteSystemProperties.IGNITE_TTL_EXPIRE_BATCH_SIZE
When cache has entries with expired TTL and/or tombstones, each user operation will also remove this amount of
expired entries.
|
static String |
IgniteSystemProperties.IGNITE_TX_DEADLOCK_DETECTION_MAX_ITERS
Specifies maximum number of iterations for deadlock detection procedure.
|
static String |
IgniteSystemProperties.IGNITE_TX_DEADLOCK_DETECTION_TIMEOUT
Specifies timeout for deadlock detection procedure.
|
static String |
IgniteSystemProperties.IGNITE_TX_OWNER_DUMP_REQUESTS_ALLOWED
Shows if dump requests from local node to near node are allowed, when long running transaction
is found.
|
static String |
IgniteSystemProperties.IGNITE_TX_SALVAGE_TIMEOUT
Deprecated.
Transactions are salvaged immediately to reduce PME latency.
|
static String |
IgniteSystemProperties.IGNITE_UNWIND_THROTTLING_TIMEOUT
Deprecated.
No longer used.
|
static String |
IgniteSystemProperties.IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI
Deprecated.
Should be removed in Apache Ignite 2.0.
|
static String |
IgniteSystemProperties.IGNITE_UPDATE_NOTIFIER
If this system property is set to
false - no checks for new versions will
be performed by Ignite. |
static String |
IgniteSystemProperties.IGNITE_USE_ASYNC_FILE_IO_FACTORY
If this property is set, then Ignite will use Async File IO factory by default.
|
static String |
IgniteSystemProperties.IGNITE_USE_LEGACY_NODE_COMPARATOR
If the property is set Ignite will use legacy node comparator (based on node order) inste
Default value is
false . |
static String |
IgniteSystemProperties.IGNITE_VALIDATE_CACHE_NAMES
If
true , cache names will be validated not to contain characters which cause issues when persistence is used
(\ , / , \0 ). |
static String |
IgniteSystemProperties.IGNITE_WAIT_FOR_BACKUPS_ON_SHUTDOWN
Deprecated.
Use
ShutdownPolicy instead. |
static String |
IgniteSystemProperties.IGNITE_WAIT_SCHEMA_UPDATE
Timeout for waiting schema update if schema was not found for last accepted version.
|
static String |
IgniteSystemProperties.IGNITE_WAL_COMPRESSOR_WORKER_THREAD_CNT
Count of WAL compressor worker threads.
|
static String |
IgniteSystemProperties.IGNITE_WAL_DEBUG_LOG_ON_RECOVERY
Default value is
false . |
static String |
IgniteSystemProperties.IGNITE_WAL_FSYNC_WITH_DEDICATED_WORKER
When set to
true , WAL implementation with dedicated worker will be used even in FSYNC mode. |
static String |
IgniteSystemProperties.IGNITE_WAL_MMAP
Property that indicates should be mapped byte buffer used or not.
|
static String |
IgniteSystemProperties.IGNITE_WAL_SEGMENT_SYNC_TIMEOUT
Property for setup Ignite WAL segment sync timeout.
|
static String |
IgniteSystemProperties.IGNITE_WAL_SERIALIZER_VERSION
Property for setup WAL serializer version.
|
static String |
IgniteSystemProperties.IGNITE_WORK_DIR
Environment variable to set work directory.
|
static String |
IgniteSystemProperties.IGNITE_ZOOKEEPER_DISCOVERY_MAX_RETRY_COUNT
Number of attempts to reconnect to ZooKeeper.
|
static String |
IgniteSystemProperties.IGNITE_ZOOKEEPER_DISCOVERY_RETRY_TIMEOUT
Timeout between ZooKeeper client retries, default 2s.
|
Modifier and Type | Field and Description |
---|---|
static String |
LocalDeploymentSpi.IGNITE_DEPLOYMENT_ADDITIONAL_CHECK
Enables additional check for resource name on resources removal.
|
GridGain In-Memory Computing Platform : ver. 8.9.14 Release Date : November 5 2024