public final class IgniteSystemProperties extends Object
Modifier and Type | Field and Description |
---|---|
static String |
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 |
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 |
GRIDGAIN_UPDATE_URL
Url of updates service.
|
static String |
IGNITE_AFFINITY_BACKUPS_THRESHOLD
Size threshold to allocate and retain additional HashMap to improve contains()
which leads to extra memory consumption.
|
static String |
IGNITE_AFFINITY_HISTORY_SIZE
Maximum size for affinity assignment history.
|
static String |
IGNITE_ALLOW_ATOMIC_OPS_IN_TX
Flag indicating whether atomic operations allowed to be used inside transactions.
|
static String |
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 |
IGNITE_ALLOW_START_CACHES_IN_PARALLEL
Enables start caches in parallel.
|
static String |
IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE
Deprecated.
No longer used.
|
static String |
IGNITE_ATOMIC_CACHE_QUEUE_RETRY_TIMEOUT
Atomic cache deferred update timeout.
|
static String |
IGNITE_ATOMIC_DEFERRED_ACK_BUFFER_SIZE
Atomic cache deferred update response buffer size.
|
static String |
IGNITE_ATOMIC_DEFERRED_ACK_TIMEOUT
Atomic cache deferred update timeout.
|
static String |
IGNITE_BASELINE_AUTO_ADJUST_LOG_INTERVAL
Interval between logging of time of next auto-adjust.
|
static String |
IGNITE_BINARY_DONT_WRAP_TREE_STRUCTURES
Deprecated.
Should be removed in Apache Ignite 2.0.
|
static String |
IGNITE_BINARY_MARSHALLER_USE_STRING_SERIALIZATION_VER_2
Manages type of serialization mechanism for
String that is marshalled/unmarshalled by BinaryMarshaller. |
static String |
IGNITE_BINARY_SORT_OBJECT_FIELDS
When set to
true fields are written by BinaryMarshaller in sorted order. |
static String |
IGNITE_BPLUS_TREE_LOCK_RETRIES
Number of repetitions to capture a lock in the B+Tree.
|
static String |
IGNITE_CACHE_CLIENT
Property controlling default behavior of cache client flag.
|
static String |
IGNITE_CACHE_KEY_VALIDATION_DISABLED
Deprecated.
Since 2.7.26. Obsolete because of common use of binary marshaller.
|
static String |
IGNITE_CACHE_REMOVED_ENTRIES_TTL
Deprecated.
No longer used.
|
static String |
IGNITE_CACHE_RETRIES_COUNT
Number of cache operation retries in case of topology exceptions.
|
static String |
IGNITE_CACHE_START_SIZE
Cache start size for on-heap maps.
|
static String |
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 |
IGNITE_CHECK_SENDER_NODE_SUBJECT
If the property is set, coincidence of client identifier and subject is required when security is enabled.
|
static String |
IGNITE_CHECKPOINT_MAP_SNAPSHOT_THRESHOLD
Threshold of the checkpoint quantity since the last earliest checkpoint map snapshot.
|
static String |
IGNITE_CHECKPOINT_READ_LOCK_TIMEOUT
Timeout for checkpoint read lock acquisition in milliseconds.
|
static String |
IGNITE_CHECKPOINT_TRIGGER_ARCHIVE_SIZE_PERCENTAGE
Property for setup percentage of archive size for checkpoint trigger.
|
static String |
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 |
IGNITE_CLUSTER_NAME
Ignite cluster name.
|
static String |
IGNITE_COMPACTED_TOPOLOGY_HISTORY
Nodes will send messages with compacted topology history.
|
static String |
IGNITE_CONFIG_URL
System property to hold optional configuration URL.
|
static String |
IGNITE_CONFIGURATION_VIEW_PACKAGES
Comma separated packages list to expose in configuration view.
|
static String |
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 |
IGNITE_CONSOLE_APPENDER
If this property is set to
true (default) and Ignite is launched
in verbose mode (see IGNITE_QUIET ) and no console appenders can be found
in configuration, then default console appender will be added. |
static String |
IGNITE_DAEMON
Presence of this system property with value
true will make the grid
node start as a daemon node. |
static String |
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 |
IGNITE_DATA_STREAMER_ALLOW_OVERWRITE |
static String |
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 |
IGNITE_DEFAULT_DATA_STORAGE_PAGE_SIZE
Sets default
storage page size . |
static String |
IGNITE_DEFAULT_DISK_PAGE_COMPRESSION
Sets default isk page compression.
|
static String |
IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_BUFFER_SIZE
One phase commit deferred ack request buffer size.
|
static String |
IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_TIMEOUT
One phase commit deferred ack request timeout.
|
static String |
IGNITE_DEFRAGMENTATION_REGION_SIZE_PERCENTAGE
Defragmentation region size percentage of configured region size.
|
static String |
IGNITE_DELAYED_REPLACED_PAGE_WRITE
When set to
true (default), pages are written to page store without holding segment lock (with delay). |
static String |
IGNITE_DEP_MODE_OVERRIDE
System property to override deployment mode configuration parameter.
|
static String |
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 |
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 |
IGNITE_DIAGNOSTIC_ENABLED |
static String |
IGNITE_DIAGNOSTIC_WARN_LIMIT
Maximum number of diagnostic warning messages per category, when waiting for PME.
|
static String |
IGNITE_DIRECT_IO_ENABLED
When set to
true , direct IO may be enabled. |
static String |
IGNITE_DISABLE_AFFINITY_MEMORY_OPTIMIZATION
Flag to disable memory optimization:
BitSets instead of HashSets to store partitions.
|
static String |
IGNITE_DISABLE_GRP_STATE_LAZY_STORE
Disable group state lazy store.
|
static String |
IGNITE_DISABLE_HOSTNAME_VERIFIER
System property to disable
HostnameVerifier for SSL connections. |
static String |
IGNITE_DISABLE_MAINTENANCE_CLEAR_FOLDER_TASK |
static String |
IGNITE_DISABLE_ONHEAP_CACHE
When set to
true , on-heap cache cannot be enabled - see
CacheConfiguration.setOnheapCacheEnabled(boolean) . |
static String |
IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION
When property is set
false each next exchange will try to compare with previous. |
static String |
IGNITE_DISABLE_SMART_DR_THROTTLING
Disables smart DR throttling.
|
static String |
IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT
Disables cache interceptor triggering in case of conflicts.
|
static String |
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 |
IGNITE_DISCO_FAILED_CLIENT_RECONNECT_DELAY
Defines reconnect delay in milliseconds for client node that was failed forcible.
|
static String |
IGNITE_DISCOVERY_CLIENT_RECONNECT_HISTORY_SIZE
Maximum number of discovery message history used to support client reconnect.
|
static String |
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 |
IGNITE_DISCOVERY_HISTORY_SIZE
Maximum size for discovery messages history.
|
static String |
IGNITE_DISCOVERY_METRICS_QNT_WARN
Logging a warning message when metrics quantity exceeded a specified number.
|
static String |
IGNITE_DUMP_PAGE_LOCK_ON_FAILURE
Enables threads locks dumping on critical node failure.
|
static String |
IGNITE_DUMP_PERSISTENCE_FILES_ON_DATA_CORRUPTION
Dumps latest WAL segments and related index and partition files on data corruption error.
|
static String |
IGNITE_DUMP_THREADS_ON_FAILURE
Enables threads dumping on critical node failure.
|
static String |
IGNITE_DUMP_THREADS_ON_FAILURE_THROTTLING_TIMEOUT
Throttling time out for thread dump generation during failure handling.
|
static String |
IGNITE_DUMP_TX_COLLISIONS_INTERVAL
When above zero, prints tx key collisions once per interval.
|
static String |
IGNITE_ENABLE_EXPERIMENTAL_COMMAND
System property to enable experimental commands in control.sh script.
|
static String |
IGNITE_ENABLE_EXTRA_INDEX_REBUILD_LOGGING
Enables extended logging of indexes create/rebuild process.
|
static String |
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 |
IGNITE_ENABLE_HASH_JOIN
Enable hash join (create hash index on the fly) for query optimizer.
|
static String |
IGNITE_ENABLE_SUBQUERY_REWRITE_OPTIMIZATION
Enables subquery rewriting optimization.
|
static String |
IGNITE_EVENT_DRIVEN_SERVICE_PROCESSOR_ENABLED
Manages the type of the implementation of the service processor (implementation of the
IgniteServices ). |
static String |
IGNITE_EVICTION_PERMITS
Deprecated.
|
static String |
IGNITE_EXCEPTION_REGISTRY_MAX_SIZE
Property controlling size of buffer holding last exception.
|
static String |
IGNITE_EXCHANGE_HISTORY_SIZE
Maximum size for exchange history.
|
static String |
IGNITE_EXCHANGE_MERGE_DELAY |
static String |
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 |
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 |
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 |
IGNITE_FORCE_MVCC_MODE_IN_TESTS
For test purposes only.
|
static String |
IGNITE_GLOBAL_METASTORAGE_HISTORY_MAX_BYTES
Maximum amount of bytes that can be stored in history of
DistributedMetaStorage updates. |
static String |
IGNITE_GRID_CLIENT_LOG_ENABLED
If this property is set to
true enable logging in GridClient . |
static String |
IGNITE_H2_DEBUG_CONSOLE
Deprecated.
Since 2.8. H2 console is no longer supported.
|
static String |
IGNITE_H2_DEBUG_CONSOLE_PORT
Deprecated.
Since 2.8. H2 console is no longer supported.
|
static String |
IGNITE_H2_INDEXING_CACHE_CLEANUP_PERIOD
System property to specify period in milliseconds between calls of the SQL statements cache cleanup task.
|
static String |
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 |
IGNITE_H2_LOCAL_RESULT_FACTORY
Defines factory class for H2 LocalResult (see org.gridgain.internal.h2.result.LocalResult).
|
static String |
IGNITE_HASH_JOIN_MAX_TABLE_SIZE
Maximum size of table (rows count) when temporary hash index can be built on fly.
|
static String |
IGNITE_HOME
Defines Ignite installation folder.
|
static String |
IGNITE_IGNORE_LOCAL_HOST_NAME
System property to ignore reading hostname of the local address.
|
static String |
IGNITE_INDEX_COST_FUNCTION
Choose the index cost function.
|
static String |
IGNITE_INDEX_REBUILD_BATCH_SIZE
Count of rows, being processed within a single checkpoint lock when indexes are rebuilt.
|
static String |
IGNITE_INDEXING_DISCOVERY_HISTORY_SIZE
Indexing discovery history size.
|
static String |
IGNITE_IO_BALANCE_PERIOD |
static String |
IGNITE_IO_DUMP_ON_TIMEOUT |
static String |
IGNITE_IPC_SHMEM_SPACE_DEBUG
If this property is set to
true then shared memory space native debug will be enabled. |
static String |
IGNITE_JCACHE_DEFAULT_ISOLATED
Property controlling whether CacheManager will start grid with isolated IP finder when default URL
is passed in.
|
static String |
IGNITE_JDBC_DRIVER_CURSOR_REMOVE_DELAY
JDBC driver cursor remove delay.
|
static String |
IGNITE_JETTY_HOST
This property allows to override Jetty host for REST processor.
|
static String |
IGNITE_JETTY_LOG_NO_OVERRIDE
This property does not allow Ignite to override Jetty log configuration for REST processor.
|
static String |
IGNITE_JETTY_PORT
This property allows to override Jetty local port for REST processor.
|
static String |
IGNITE_JOBS_HISTORY_SIZE
System property to override default job processor maps sizes for finished jobs and
cancellation requests.
|
static String |
IGNITE_JOBS_METRICS_CONCURRENCY_LEVEL
Deprecated.
Use
GridMetricManager instead. |
static String |
IGNITE_JVM_PAUSE_DETECTOR_DISABLED
Ignite JVM pause detector disabled.
|
static String |
IGNITE_JVM_PAUSE_DETECTOR_LAST_EVENTS_COUNT
Ignite JVM pause detector last events count.
|
static String |
IGNITE_JVM_PAUSE_DETECTOR_PRECISION
Ignite JVM pause detector precision.
|
static String |
IGNITE_JVM_PAUSE_DETECTOR_THRESHOLD
Ignite JVM pause detector threshold.
|
static String |
IGNITE_KEEP_STATIC_CACHE_CONFIGURATION
Keep static cache configuration even if stored cache data differs from the static config.
|
static String |
IGNITE_KEEP_UNCLEARED_EXCHANGE_FUTURES_LIMIT
Defines how many exchange futures are kept uncleared in the queue.
|
static String |
IGNITE_LOADED_PAGES_BACKWARD_SHIFT_MAP
When set to
false , loaded pages implementation is switched to previous version of implementation,
FullPageIdTable. |
static String |
IGNITE_LOCAL_HOST
The system property sets a system-wide local IP address or hostname to be used by Ignite networking components.
|
static String |
IGNITE_LOCAL_STORE_KEEPS_PRIMARY_ONLY
Indicating whether local store keeps primary only.
|
static String |
IGNITE_LOG_CLASSPATH_CONTENT_ON_STARTUP
Scan the classpath on startup and log all the files containing in it.
|
static String |
IGNITE_LOG_DIR
Environment variable to override logging directory that has been set in logger configuration.
|
static String |
IGNITE_LOG_GRID_NAME
Deprecated.
|
static String |
IGNITE_LOG_INSTANCE_NAME
If this system property is present the Ignite will include instance name into verbose log.
|
static String |
IGNITE_LOG_THROTTLE_CAPACITY
Max amount of remembered errors for
GridLogThrottle . |
static String |
IGNITE_LONG_LONG_HASH_MAP_LOAD_FACTOR
Long-long offheap map load factor.
|
static String |
IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT
Cache operations that take more time than value of this property will be output to log.
|
static String |
IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT_LIMIT
Upper time limit between long running/hanging operations debug dumps.
|
static String |
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 |
IGNITE_MAINTENANCE_AUTO_SHUTDOWN_AFTER_RECOVERY
Node in maintenance mode will automatically shut down after all active maintenance would be completed.
|
static String |
IGNITE_MAINTENANCE_MODE_EXIT_CODE
Node in maintenance mode will shut down with specified JVM exit code.
|
static String |
IGNITE_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE
System property to specify per thread binary allocator chunk pool size.
|
static String |
IGNITE_MARSHAL_BUFFERS_RECHECK
System property to specify how often in milliseconds marshal buffers
should be rechecked and potentially trimmed.
|
static String |
IGNITE_MARSHALLER_BLACKLIST
Defines path to the file that contains list of classes disallowed to safe deserialization.
|
static String |
IGNITE_MARSHALLER_WHITELIST
Defines path to the file that contains list of classes allowed to safe deserialization.
|
static String |
IGNITE_MASTER_KEY_NAME_TO_CHANGE_BEFORE_STARTUP
The master key name that the node will use during the recovery.
|
static String |
IGNITE_MAX_COMPLETED_TX_COUNT
Property controlling size of buffer holding completed transaction versions.
|
static String |
IGNITE_MAX_INDEX_PAYLOAD_SIZE
System property to specify maximum payload size in bytes for
H2TreeIndex . |
static String |
IGNITE_MAX_NESTED_LISTENER_CALLS
Maximum number of nested listener calls before listener notification becomes asynchronous.
|
static String |
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 |
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 |
IGNITE_MBEANS_DISABLED
If property is set to
true , then Ignite will disable MBeans registration. |
static String |
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 |
IGNITE_MEMORY_UNALIGNED_ACCESS
Whether Ignite can access unaligned memory addresses.
|
static String |
IGNITE_MIN_AFFINITY_HISTORY_SIZE
Minimum size for affinity assignment history.
|
static String |
IGNITE_MIN_BUFFERED_COMMUNICATION_MSG_CNT
Deprecated.
Not used anymore.
|
static String |
IGNITE_MVCC_TX_SIZE_CACHING_THRESHOLD
Maximum number for cached MVCC transaction updates.
|
static String |
IGNITE_NEAR_GET_MAX_REMAPS
This property defines the maximum number of attempts to remap near get to the same
primary node.
|
static String |
IGNITE_NIO_RECOVERY_DESCRIPTOR_RESERVATION_TIMEOUT
Sets timeout for TCP client recovery descriptor reservation.
|
static String |
IGNITE_NO_ASCII
If this system property is present (any value) - no ASCII logo will
be printed.
|
static String |
IGNITE_NO_DISCO_ORDER
Name of the system property to disable requirement for proper node ordering
by discovery SPI.
|
static String |
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 |
IGNITE_NO_SHUTDOWN_HOOK
If this system property is set to
true - no shutdown hook will be set. |
static String |
IGNITE_NODE_IDS_HISTORY_SIZE
Maximum size of history of server nodes (server node IDs) that ever joined to current topology.
|
static String |
IGNITE_OFFHEAP_LOCK_CONCURRENCY_LEVEL
Ignite page memory concurrency level.
|
static String |
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 |
IGNITE_OPTIMIZED_MARSHALLER_USE_DEFAULT_SUID
|
static String |
IGNITE_OVERRIDE_CONSISTENT_ID
System property to specify consistent id of Ignite node.
|
static String |
IGNITE_OVERRIDE_MCAST_GRP
System property to override multicast group taken from configuration.
|
static String |
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 |
IGNITE_PAGE_LOCK_TRACKER_CAPACITY
Capacity in pages for storing in page lock tracker strucuture.
|
static String |
IGNITE_PAGE_LOCK_TRACKER_CHECK_INTERVAL
Page lock tracker thread for checking hangs threads interval.
|
static String |
IGNITE_PAGE_LOCK_TRACKER_TYPE
Page lock tracker type
|
static String |
IGNITE_PAGES_LIST_DISABLE_ONHEAP_CACHING |
static String |
IGNITE_PART_DISTRIBUTION_WARN_THRESHOLD
The threshold of uneven distribution above which partition distribution will be logged.
|
static String |
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 |
IGNITE_PARTITION_RELEASE_FUTURE_WARN_LIMIT
This property specifies the maximum number of futures that are included into diagnostic message.
|
static String |
IGNITE_PDS_MAX_CHECKPOINT_MEMORY_HISTORY_SIZE
Number of checkpoint history entries held in memory.
|
static String |
IGNITE_PDS_PARTITION_DESTROY_CHECKPOINT_DELAY
Deprecated.
|
static String |
IGNITE_PDS_SKIP_CRC
Skip CRC calculation flag.
|
static String |
IGNITE_PDS_WAL_REBALANCE_THRESHOLD
Deprecated.
use Distributed MetaStorage property
GridCacheDatabaseSharedManager.HISTORICAL_REBALANCE_THRESHOLD_DMS_KEY . |
static String |
IGNITE_PENDING_TX_TRACKER_ENABLED
System property to enable pending transaction tracker.
|
static String |
IGNITE_PERFORMANCE_SUGGESTIONS_DISABLED
Flag indicating whether performance suggestions output on start should be disabled.
|
static String |
IGNITE_PREFER_WAL_REBALANCE
Prefer historical rebalance if there's enough history regardless of all heuristics.
|
static String |
IGNITE_PRELOAD_RESEND_TIMEOUT
System property to hold preload resend timeout for evicted partitions.
|
static String |
IGNITE_PROG_NAME
Name of the system property defining name of command line program.
|
static String |
IGNITE_QUIET
Set to either
true or false to enable or disable quiet mode
of Ignite. |
static String |
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 |
IGNITE_REBALANCE_STATISTICS_TIME_INTERVAL
Deprecated.
Use
MetricsMxBean.configureHitRateMetric(String, long) instead. |
static String |
IGNITE_REBALANCE_THROTTLE_OVERRIDE
Deprecated.
Use
IgniteConfiguration.getRebalanceThrottle() instead. |
static String |
IGNITE_RECOVERY_SEMAPHORE_PERMITS
Limit the maximum number of objects in memory during the recovery procedure.
|
static String |
IGNITE_RECOVERY_VERBOSE_LOGGING
Allows to log additional information about all restored partitions after binary and logical recovery phases.
|
static String |
IGNITE_REFLECTION_CACHE_SIZE
System property to override default reflection cache size.
|
static String |
IGNITE_REST_GETALL_AS_ARRAY
Deprecated.
Should be made default in Apache Ignite 3.0.
|
static String |
IGNITE_REST_MAX_TASK_RESULTS
This property allows to override maximum count of task results stored on one node
in REST processor.
|
static String |
IGNITE_REST_SECURITY_TOKEN_TIMEOUT
This property allow rewriting default (
300 ) REST session security token expire time (in seconds). |
static String |
IGNITE_REST_SESSION_TIMEOUT
This property allow rewriting default (
30 ) REST session expire time (in seconds). |
static String |
IGNITE_REST_START_ON_CLIENT
This property allows to override default behavior that rest processor
doesn't start on client node.
|
static String |
IGNITE_RESTART_CODE
This property is used internally to pass an exit code to loader when
Ignite instance is being restarted.
|
static String |
IGNITE_REUSE_MEMORY_ON_DEACTIVATE
Try reuse memory on deactivation.
|
static String |
IGNITE_SECURITY_COMPATIBILITY_MODE
When set to
true , Ignite switches to compatibility mode with versions that don't
support service security permissions. |
static String |
IGNITE_SECURITY_FOR_SYS_CACHE_ENABLED
If the property is set, client nodes should have explicitly rights to access to system cache.
|
static String |
IGNITE_SENSITIVE_DATA_LOGGING
Setting to
"plain" enables writing sensitive information in toString() output. |
static String |
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 |
IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK
Property allowing to skip configuration consistency checks.
|
static String |
IGNITE_SKIP_PARTITION_SIZE_VALIDATION
When set to
true , Ignite will skip partitions sizes check on partition validation after rebalance has finished. |
static String |
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 |
IGNITE_SQL_ALLOW_KEY_VAL_UPDATES
Allow use composite _key, _val columns at the INSERT/UPDATE/MERGE statements.
|
static String |
IGNITE_SQL_DISABLE_SYSTEM_VIEWS
Disable SQL system views.
|
static String |
IGNITE_SQL_DISTINCT_RESULTS_USE_TREE_MAP
Use TreeMap instead of HashMap to hold distinct values.
|
static String |
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 |
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 |
IGNITE_SQL_MAX_EXTRACTED_PARTS_FROM_BETWEEN
Maximum number of different partitions to be extracted from between expression within sql query.
|
static String |
IGNITE_SQL_MEMORY_RESERVATION_BLOCK_SIZE
Defines default memory reservation block size.
|
static String |
IGNITE_SQL_MERGE_TABLE_MAX_SIZE
Property controlling maximum number of SQL result rows which can be fetched into a merge table.
|
static String |
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 |
IGNITE_SQL_PARSER_DISABLE_H2_FALLBACK
Disable fallback to H2 SQL parser if the internal SQL parser fails to parse the statement.
|
static String |
IGNITE_SQL_RETRY_TIMEOUT
SQL retry timeout.
|
static String |
IGNITE_SQL_SYSTEM_SCHEMA_NAME_IGNITE
Enable backward compatible to use 'IGNITE' as SQL system schema.
|
static String |
IGNITE_SQL_UUID_DDL_BYTE_FORMAT
Enable backward compatible handling of UUID through DDL.
|
static String |
IGNITE_SSH_HOST
System property to hold SSH host for visor-started nodes.
|
static String |
IGNITE_SSH_USER_NAME
System property to hold SSH user name for visor-started nodes.
|
static String |
IGNITE_SSL_HANDSHAKE_TIMEOUT
SSL handshake timeout.
|
static String |
IGNITE_SSL_UNWRAP_TIMEOUT
SSL unwrap timeout.
|
static String |
IGNITE_START_CACHES_ON_JOIN |
static String |
IGNITE_STARVATION_CHECK_INTERVAL
This system property defines interval in milliseconds in which Ignite will check
thread pool state for starvation.
|
static String |
IGNITE_STREAM_TRANSFORMER_COMPATIBILITY_MODE
Manages backward compatibility of
StreamTransformer.from(CacheEntryProcessor) method. |
static String |
IGNITE_STRICT_CONSISTENCY_CHECK
Enables strict mode to check not critical internal invariants.
|
static String |
IGNITE_SUCCESS_FILE
Deprecated.
No longer used.
|
static String |
IGNITE_SYSTEM_WORKER_BLOCKED_TIMEOUT
Maximum inactivity period for system worker in milliseconds.
|
static String |
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 |
IGNITE_TCP_DISCOVERY_ADDRESSES
Comma separated list of addresses in format "10.100.22.100:45000,10.100.22.101:45000".
|
static String |
IGNITE_TEST_ENV
Set to true only during the junit tests.
|
static String |
IGNITE_TEST_FEATURES_ENABLED
If property is set to
true , then test features will be enabled. |
static String |
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 |
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 |
IGNITE_THRESHOLD_WAL_ARCHIVE_SIZE_PERCENTAGE
Deprecated.
|
static String |
IGNITE_THROTTLE_LOG_THRESHOLD
Threshold for throttling operations logging.
|
static String |
IGNITE_TO_STRING_COLLECTION_LIMIT
Limit collection (map, array) elements number to output.
|
static String |
IGNITE_TO_STRING_INCLUDE_SENSITIVE
Deprecated.
Use
IGNITE_SENSITIVE_DATA_LOGGING instead. |
static String |
IGNITE_TO_STRING_MAX_LENGTH
Maximum length for
toString() result. |
static String |
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 |
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT
The coefficient for samples of completed transactions that will be dumped in log.
|
static String |
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_PER_SECOND_LIMIT
The limit of samples of completed transactions that will be dumped in log per second, if
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT is above 0.0 . |
static String |
IGNITE_TROUBLESHOOTING_LOGGER
Setting this option to
true will enable troubleshooting logger. |
static String |
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 |
IGNITE_TX_DEADLOCK_DETECTION_MAX_ITERS
Specifies maximum number of iterations for deadlock detection procedure.
|
static String |
IGNITE_TX_DEADLOCK_DETECTION_TIMEOUT
Specifies timeout for deadlock detection procedure.
|
static String |
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 |
IGNITE_TX_SALVAGE_TIMEOUT
Deprecated.
Transactions are salvaged immediately to reduce PME latency.
|
static String |
IGNITE_UNWIND_THROTTLING_TIMEOUT
Deprecated.
No longer used.
|
static String |
IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI
Deprecated.
Should be removed in Apache Ignite 2.0.
|
static String |
IGNITE_UPDATE_NOTIFIER
If this system property is set to
false - no checks for new versions will
be performed by Ignite. |
static String |
IGNITE_USE_ASYNC_FILE_IO_FACTORY
If this property is set, then Ignite will use Async File IO factory by default.
|
static String |
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 |
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 |
IGNITE_WAIT_FOR_BACKUPS_ON_SHUTDOWN
Deprecated.
Use
ShutdownPolicy instead. |
static String |
IGNITE_WAIT_SCHEMA_UPDATE
Timeout for waiting schema update if schema was not found for last accepted version.
|
static String |
IGNITE_WAL_COMPRESSOR_WORKER_THREAD_CNT
Count of WAL compressor worker threads.
|
static String |
IGNITE_WAL_DEBUG_LOG_ON_RECOVERY
Default value is
false . |
static String |
IGNITE_WAL_FSYNC_WITH_DEDICATED_WORKER
When set to
true , WAL implementation with dedicated worker will be used even in FSYNC mode. |
static String |
IGNITE_WAL_MMAP
Property that indicates should be mapped byte buffer used or not.
|
static String |
IGNITE_WAL_SEGMENT_SYNC_TIMEOUT
Property for setup Ignite WAL segment sync timeout.
|
static String |
IGNITE_WAL_SERIALIZER_VERSION
Property for setup WAL serializer version.
|
static String |
IGNITE_WORK_DIR
Environment variable to set work directory.
|
static String |
IGNITE_ZOOKEEPER_DISCOVERY_MAX_RETRY_COUNT
Number of attempts to reconnect to ZooKeeper.
|
static String |
IGNITE_ZOOKEEPER_DISCOVERY_RETRY_TIMEOUT
Timeout between ZooKeeper client retries, default 2s.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
getBoolean(String name)
Gets either system property or environment variable with given name.
|
static boolean |
getBoolean(String name,
boolean dflt)
Gets either system property or environment variable with given name.
|
static double |
getDouble(String name,
double dflt)
Gets either system property or environment variable with given name.
|
static <E extends Enum<E>> |
getEnum(Class<E> enumCls,
String name) |
static <E extends Enum<E>> |
getEnum(String name,
E dflt) |
static float |
getFloat(String name,
float dflt)
Gets either system property or environment variable with given name.
|
static int |
getInteger(String name,
int dflt)
Gets either system property or environment variable with given name.
|
static long |
getLong(String name,
long dflt)
Gets either system property or environment variable with given name.
|
static @Nullable String |
getString(String name)
Gets either system property or environment variable with given name.
|
static @Nullable String |
getString(String name,
String dflt)
Gets either system property or environment variable with given name.
|
static UUID |
getUUID(String name,
UUID dflt)
Gets either system property or environment variable with given name.
|
static Properties |
snapshot()
Gets snapshot of system properties.
|
@Deprecated @SystemProperty(value="If this system property is present Ignite will include grid name into verbose log", type=java.lang.String.class) public static final String IGNITE_LOG_GRID_NAME
IGNITE_LOG_INSTANCE_NAME
.@SystemProperty(value="If this system property is present Ignite will include instance name into verbose log", type=java.lang.String.class) public static final String IGNITE_LOG_INSTANCE_NAME
@SystemProperty(value="Exit code to pass to loader when Ignite instance is being restarted", type=java.lang.Integer.class, defaults="0") public static final String IGNITE_RESTART_CODE
@SystemProperty(value="If true Ignite will start as a daemon node. Note that this system property will override IgniteConfiguration.isDaemon() configuration") public static final String IGNITE_DAEMON
true
will make the grid
node start as a daemon node. Node that this system property will override
IgniteConfiguration.isDaemon()
configuration.@SystemProperty(value="Defines Ignite installation folder", type=java.lang.String.class, defaults="") public static final String IGNITE_HOME
@SystemProperty(value="If true then no shutdown hook will be set") public static final String IGNITE_NO_SHUTDOWN_HOOK
true
- no shutdown hook will be set.@SystemProperty(value="If true requirement for proper node ordering by discovery SPI will be disabled. Use with care, as proper node ordering is required for cache consistency. If set to true, then any discovery SPI can be used with distributed cache, otherwise, only discovery SPIs that have annotation @GridDiscoverySpiOrderSupport(true) will be allowed") public static final String IGNITE_NO_DISCO_ORDER
true
, then any discovery SPI can be used
with distributed cache, otherwise, only discovery SPIs that have annotation
@GridDiscoverySpiOrderSupport(true)
will
be allowed.@SystemProperty(value="Reconnect delay in milliseconds for client node that was failed forcible", type=java.lang.Long.class, defaults="10000 milliseconds") public static final String IGNITE_DISCO_FAILED_CLIENT_RECONNECT_DELAY
@SystemProperty(value="If this system property is set to false - no checks for new versions will be performed by Ignite. By default, Ignite periodically checks for the new version and prints out the message into the log if a new version of Ignite is available for download. Update notifier enabled flag is a cluster-wide value and determined according to the local setting during the start of the first node in the cluster. The chosen value will survive the first node shutdown and will override the property value on all newly joining nodes", defaults="true") public static final String IGNITE_UPDATE_NOTIFIER
false
- no checks for new versions will
be performed by Ignite. By default, Ignite periodically checks for the new
version and prints out the message into the log if a new version of Ignite is
available for download.
Update notifier enabled flag is a cluster-wide value and determined according to the local setting
during the start of the first node in the cluster. The chosen value will survive the first node shutdown
and will override the property value on all newly joining nodes.@SystemProperty(value="Url of updates service", type=java.lang.String.class, defaults="https://www.gridgain.com/notifier/update") public static final String GRIDGAIN_UPDATE_URL
@SystemProperty(value="Interval in milliseconds in which Ignite will check thread pool state for starvation. Zero value will disable checker", type=java.lang.Long.class, defaults="30000 milliseconds") public static final String IGNITE_STARVATION_CHECK_INTERVAL
@SystemProperty(value="If this system property is present (any value) - no ASCII logo will be printed") public static final String IGNITE_NO_ASCII
@SystemProperty(value="Jetty host for REST processor", type=java.lang.String.class) public static final String IGNITE_JETTY_HOST
@SystemProperty(value="Jetty local port for REST processor", type=java.lang.Integer.class) public static final String IGNITE_JETTY_PORT
@SystemProperty(value="If true then disallow Ignite to override Jetty log configuration for REST processor") public static final String IGNITE_JETTY_LOG_NO_OVERRIDE
@SystemProperty(value="REST session expire time in seconds", type=java.lang.Long.class, defaults="30 seconds") public static final String IGNITE_REST_SESSION_TIMEOUT
30
) REST session expire time (in seconds).@SystemProperty(value="REST session security token expire time in seconds", type=java.lang.Long.class, defaults="300 seconds") public static final String IGNITE_REST_SECURITY_TOKEN_TIMEOUT
300
) REST session security token expire time (in seconds).@SystemProperty(value="Maximum count of task results stored on one node in REST processor", type=java.lang.Integer.class, defaults="10240") public static final String IGNITE_REST_MAX_TASK_RESULTS
@SystemProperty(value="This property allows to override default behavior that rest processor doesn\'t start on client node. If set {@code true} than rest processor will be started on client node", defaults="false") public static final String IGNITE_REST_START_ON_CLIENT
true
than rest processor will be started on client node.@Deprecated @SystemProperty(value="Changes output format of {@link GridRestCommand#CACHE_GET_ALL} from {k: v, ...} to [{\"key\": k, \"value\": v}, ...] to allow non-string keys output", defaults="false") public static final String IGNITE_REST_GETALL_AS_ARRAY
GridRestCommand.CACHE_GET_ALL
from {k: v, ...}
to [{"key": k, "value": v}, ...] to allow non-string keys output.@SystemProperty(value="Defines the maximum number of attempts to remap near get to the same primary node. Remapping may be needed when topology is changed concurrently with get operation", type=java.lang.Integer.class, defaults="3") public static final String IGNITE_NEAR_GET_MAX_REMAPS
@SystemProperty(value="In quiet mode, only warning and errors are printed into the log additionally to a shortened version of standard output on the start. Note that if you use ignite.{sh|bat} scripts to start Ignite they start by default in verbose mode. You can supply -q flag to override it", defaults="false") public static final String IGNITE_QUIET
true
or false
to enable or disable quiet mode
of Ignite. In quiet mode, only warning and errors are printed into the log
additionally to a shortened version of standard output on the start.
Note that if you use ignite.{sh|bat} scripts to start Ignite they start by default in verbose mode. You can supply -q flag to override it.
@SystemProperty(value="Enables troubleshooting logger. Troubleshooting logger makes logging more verbose without enabling debug mode to provide more detailed logs without performance penalty") public static final String IGNITE_TROUBLESHOOTING_LOGGER
true
will enable troubleshooting logger.
Troubleshooting logger makes logging more verbose without enabling debug mode
to provide more detailed logs without performance penalty.@Deprecated @SystemProperty(value="Enables writing sensitive information in toString() output") public static final String IGNITE_TO_STRING_INCLUDE_SENSITIVE
IGNITE_SENSITIVE_DATA_LOGGING
instead.true
enables writing sensitive information in toString()
output.@SystemProperty(value="Setting to {@code \"plain\"} enables writing sensitive information in {@code toString()} output. Setting to {@code \"hash\"} enables writing hash of sensitive information in {@code toString()} output. Setting to {@code \"none\"} disables writing sensitive information in {@code toString()} output. IGNITE_TO_STRING_INCLUDE_SENSITIVE has higher priority. If it is explicitly set, then it is converted: \"true\" -> \"plain\", \"false\" -> \"none\"", type=java.lang.String.class, defaults="hash") public static final String IGNITE_SENSITIVE_DATA_LOGGING
"plain"
enables writing sensitive information in toString()
output.
Setting to "hash"
enables writing hash of sensitive information in toString()
output.
Setting to "none"
disables writing sensitive information in toString()
output.
IGNITE_TO_STRING_INCLUDE_SENSITIVE
has higher priority. If it is explicitly set, then it is converted:
"true" -> "plain",
"false" -> "none".@SystemProperty(value="Maximum length for toString() result", type=java.lang.Integer.class, defaults="10000") public static final String IGNITE_TO_STRING_MAX_LENGTH
toString()
result.@SystemProperty(value="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", defaults="false") public static final String IGNITE_TO_STRING_THROW_RUNTIME_EXCEPTION
GridToStringBuilder
should throw RuntimeException
when building string representation of an object or should just print information about exception into the log
and proceed.
False
by default.@SystemProperty(value="Number of collection (map, array) elements to output", type=java.lang.Integer.class, defaults="100") public static final String IGNITE_TO_STRING_COLLECTION_LIMIT
@SystemProperty(value="If true (default) and Ignite is launched in verbose mode (see IGNITE_QUIET) and no console appenders can be found in configuration, then default console appender will be added. Set this property to false if no appenders should be added", defaults="true") public static final String IGNITE_CONSOLE_APPENDER
true
(default) and Ignite is launched
in verbose mode (see IGNITE_QUIET
) and no console appenders can be found
in configuration, then default console appender will be added.
Set this property to false
if no appenders should be added.@SystemProperty(value="Maximum size for exchange history", type=java.lang.Integer.class, defaults="1000") public static final String IGNITE_EXCHANGE_HISTORY_SIZE
1000
.@SystemProperty(value="Partition map exchange merge delay in milliseconds", type=java.lang.Long.class, defaults="0") public static final String IGNITE_EXCHANGE_MERGE_DELAY
@SystemProperty(value="Name of command line program", type=java.lang.String.class, defaults="ignite.{sh|bat}") public static final String IGNITE_PROG_NAME
@SystemProperty(value="Success file name. This file is used with auto-restarting functionality when Ignite is started by supplied ignite.{bat|sh} scripts", type=java.lang.String.class) @Deprecated public static final String IGNITE_SUCCESS_FILE
@SystemProperty(value="Sets a system-wide local IP address or hostname to be used by Ignite networking components. Once provided, the property overrides all the default local binding settings for Ignite nodes. Note, that the address can also be changed via IgniteConfiguration.setLocalHost(String) method. However, this system property has bigger priority and overrides the settings set via IgniteConfiguration", type=java.lang.String.class) public static final String IGNITE_LOCAL_HOST
Note, that the address can also be changed via
IgniteConfiguration.setLocalHost(String)
method.
However, this system property has bigger priority and overrides the settings set via
IgniteConfiguration
.
@SystemProperty(value="Sets deployment mode configuration parameter. Valid values for property are: PRIVATE, ISOLATED, SHARED or CONTINUOUS", type=DeploymentMode.class) public static final String IGNITE_DEP_MODE_OVERRIDE
@SystemProperty(value="Size of buffer holding completed transaction versions. Buffer is used to detect duplicate transaction. In most cases this value is large enough and does not need to be changed", type=java.lang.Integer.class, defaults="262144") public static final String IGNITE_MAX_COMPLETED_TX_COUNT
102400
. In
most cases this value is large enough and does not need to be changed.@SystemProperty(value="Transactions that take more time, than value of this property (in milliseconds), will be output to warnings. 0 disables warnings on slow transactions", type=java.lang.Integer.class, defaults="0") public static final String IGNITE_SLOW_TX_WARN_TIMEOUT
0
(default value) disables warning on slow transactions.@Deprecated @SystemProperty(value="Timeout after which all uncompleted transactions originated by left node will be\n * salvaged (i.e. invalidated and committed)") public static final String IGNITE_TX_SALVAGE_TIMEOUT
@SystemProperty(value="Maximum number of iterations for deadlock detection procedure. If value of this property is less then or equal to zero then deadlock detection will be disabled", type=java.lang.Integer.class, defaults="1000") public static final String IGNITE_TX_DEADLOCK_DETECTION_MAX_ITERS
@SystemProperty(value="Timeout for deadlock detection procedure", type=java.lang.Integer.class, defaults="60000") public static final String IGNITE_TX_DEADLOCK_DETECTION_TIMEOUT
@SystemProperty(value="Enables pending transaction tracker. Affects impact of IGNITE_DISABLE_WAL_DURING_REBALANCING property: if this property is set, WAL anyway won\'t be disabled during rebalancing triggered by baseline topology change", defaults="false") public static final String IGNITE_PENDING_TX_TRACKER_ENABLED
IGNITE_DISABLE_WAL_DURING_REBALANCING
property:
if this property is set, WAL anyway won't be disabled during rebalancing triggered by baseline topology change.
Now it is not nessessary setting this property before grid starting because enabling of pendingTxTracker happens
automatically if needed, and it should be used for test purposes only.@SystemProperty(value="Overrides multicast group taken from configuration. Used for testing purposes", type=java.lang.String.class) public static final String IGNITE_OVERRIDE_MCAST_GRP
@SystemProperty(value="Overrides default reflection cache size", type=java.lang.Integer.class, defaults="128") public static final String IGNITE_REFLECTION_CACHE_SIZE
128
.@SystemProperty(value="Job processor maps sizes for finished jobs and cancellation requests. ", type=java.lang.Integer.class, defaults="10240") public static final String IGNITE_JOBS_HISTORY_SIZE
10240
.@Deprecated @SystemProperty(value="Job metrics processor property defining concurrency level for structure holding job metrics snapshots", type=java.lang.Integer.class, defaults="64") public static final String IGNITE_JOBS_METRICS_CONCURRENCY_LEVEL
GridMetricManager
instead.64
.@SystemProperty(value="Configuration URL", type=java.lang.String.class) public static final String IGNITE_CONFIG_URL
@SystemProperty(value="SSH host name for visor-started nodes", type=java.lang.String.class) public static final String IGNITE_SSH_HOST
@SystemProperty(value="Enables experimental commands in control.sh script") public static final String IGNITE_ENABLE_EXPERIMENTAL_COMMAND
@SystemProperty(value="SSH user name for visor-started nodes", type=java.lang.String.class) public static final String IGNITE_SSH_USER_NAME
@SystemProperty(value="Preload resend timeout for evicted partitions in milliseconds", type=java.lang.Long.class, defaults="1500") public static final String IGNITE_PRELOAD_RESEND_TIMEOUT
@SystemProperty(value="How often in milliseconds marshal buffers should be rechecked and potentially trimmed", type=java.lang.Long.class, defaults="10000") public static final String IGNITE_MARSHAL_BUFFERS_RECHECK
10,000ms
.@SystemProperty(value="Per thread binary allocator chunk pool size", type=java.lang.Integer.class, defaults="32") public static final String IGNITE_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE
32
.@SystemProperty(value="Disables HostnameVerifier for SSL connections. Can be used for development with self-signed certificates", defaults="false") public static final String IGNITE_DISABLE_HOSTNAME_VERIFIER
HostnameVerifier
for SSL connections.
Can be used for development with self-signed certificates. Default value is false
.@Deprecated @SystemProperty(value="Disables buffered communication if node sends less messages count than specified by this property", type=java.lang.Integer.class, defaults="512") public static final String IGNITE_MIN_BUFFERED_COMMUNICATION_MSG_CNT
512
.@SystemProperty(value="Force Ignite to fill memory block with some recognisable pattern right before this memory block is released. This will help to recognize cases when already released memory is accessed") public static final String IGNITE_OFFHEAP_SAFE_RELEASE
@Deprecated @SystemProperty(value="Maximum size for atomic cache queue delete history", type=java.lang.Integer.class, defaults="200000 per partition") public static final String IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE
@Deprecated @SystemProperty(value="Ttl of removed cache entries in milliseconds", type=java.lang.Long.class) public static final String IGNITE_CACHE_REMOVED_ENTRIES_TTL
@SystemProperty(value="Comma separated list of addresses in format \"10.100.22.100:45000,10.100.22.101:45000\". Used only for org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder", type=java.lang.String.class) public static final String IGNITE_TCP_DISCOVERY_ADDRESSES
TcpDiscoveryVmIpFinder
.@SystemProperty(value="Disables performance suggestions output on start", defaults="false") public static final String IGNITE_PERFORMANCE_SUGGESTIONS_DISABLED
@SystemProperty(value="Allows atomic operations inside transactions", defaults="false") public static final String IGNITE_ALLOW_ATOMIC_OPS_IN_TX
@SystemProperty(value="Atomic cache deferred update response buffer size", type=java.lang.Integer.class, defaults="256") public static final String IGNITE_ATOMIC_DEFERRED_ACK_BUFFER_SIZE
@SystemProperty(value="Atomic cache deferred update response buffer size", type=java.lang.Integer.class, defaults="256") public static final String IGNITE_ATOMIC_DEFERRED_ACK_TIMEOUT
@SystemProperty(value="Atomic cache deferred update timeout", type=java.lang.Integer.class, defaults="500") public static final String IGNITE_ATOMIC_CACHE_QUEUE_RETRY_TIMEOUT
@SystemProperty(value="One phase commit deferred ack request timeout", type=java.lang.Integer.class, defaults="500") public static final String IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_TIMEOUT
@SystemProperty(value="One phase commit deferred ack request buffer size", type=java.lang.Integer.class, defaults="256") public static final String IGNITE_DEFERRED_ONE_PHASE_COMMIT_ACK_REQUEST_BUFFER_SIZE
@Deprecated @SystemProperty(value="Enables debug console for H2 indexing SPI", type=java.lang.String.class) public static final String IGNITE_H2_DEBUG_CONSOLE
@Deprecated @SystemProperty(value="User defined port which H2 indexing SPI will use to start H2 debug console on. If this property is not set or set to 0, H2 debug console will use system-provided dynamic port. This property is only relevant when IGNITE_H2_DEBUG_CONSOLE property is set", type=java.lang.Integer.class) public static final String IGNITE_H2_DEBUG_CONSOLE_PORT
IGNITE_H2_DEBUG_CONSOLE
property is set.@SystemProperty(value="Enables native debug of the shared memory space", defaults="false") public static final String IGNITE_IPC_SHMEM_SPACE_DEBUG
true
then shared memory space native debug will be enabled.@SystemProperty(value="Skip configuration consistency checks", defaults="false") public static final String IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK
@Deprecated @SystemProperty(value="Disables validation of keys put to cache") public static final String IGNITE_CACHE_KEY_VALIDATION_DISABLED
@SystemProperty(value="Logging directory. Overrides configuration value", type=java.lang.String.class) public static final String IGNITE_LOG_DIR
@SystemProperty(value="Work directory. The property IgniteConfiguration.setWorkDirectory has higher priority", type=java.lang.String.class) public static final String IGNITE_WORK_DIR
IgniteConfiguration.setWorkDirectory(java.lang.String)
has higher
priority.@SystemProperty(value="Enables Ignite to append hash code of Ignite class as hex string and append JVM name returned by RuntimeMXBean.getName(). This may be helpful when running Ignite in some application server clusters or similar environments to avoid MBean name collisions") public static final String IGNITE_MBEAN_APPEND_JVM_ID
true
then Ignite will append
hash code of Ignite
class as hex string and append
JVM name returned by RuntimeMXBean.getName()
.
This may be helpful when running Ignite in some application server clusters or similar environments to avoid MBean name collisions.
Default is false
.
@SystemProperty(value="Enables Ignite to append hash code of class loader to MXBean name", defaults="true") public static final String IGNITE_MBEAN_APPEND_CLASS_LOADER_ID
true
then Ignite will append
hash code of class loader to MXBean name.
Default is true
.
@SystemProperty(value="Disable MBeans registration. This may be helpful if MBeans are not allowed e.g. for security reasons", defaults="false") public static final String IGNITE_MBEANS_DISABLED
true
, then Ignite will disable MBeans registration.
This may be helpful if MBeans are not allowed e.g. for security reasons.
Default is false
@SystemProperty(value="Enables test features", defaults="false") public static final String IGNITE_TEST_FEATURES_ENABLED
true
, then test features will be enabled.
Default is false
.@SystemProperty(value="Size of buffer holding last exception", type=java.lang.Integer.class, defaults="1000") public static final String IGNITE_EXCEPTION_REGISTRY_MAX_SIZE
1000
.@SystemProperty(value="Starts node in client mode. Have lower priority than configuration value", defaults="false") public static final String IGNITE_CACHE_CLIENT
@SystemProperty(value="Enables CacheManager to start grid with isolated IP finder when default URL is passed in. This is needed to pass TCK tests which use default URL and assume isolated cache managers for different class loaders", defaults="true") public static final String IGNITE_JCACHE_DEFAULT_ISOLATED
@SystemProperty(value="Maximum number of SQL result rows which can be fetched into a merge table. If there are less rows than this threshold then multiple passes throw a table will be possible, otherwise only one pass (e.g. only result streaming is possible)", type=java.lang.Integer.class, defaults="10000") public static final String IGNITE_SQL_MERGE_TABLE_MAX_SIZE
@SystemProperty(value="Number of SQL result rows that will be fetched into a merge table at once before applying binary search for the bounds", type=java.lang.Integer.class, defaults="1024") public static final String IGNITE_SQL_MERGE_TABLE_PREFETCH_SIZE
@SystemProperty(value="Disables fallback to H2 SQL parser if the internal SQL parser fails to parse the statement", defaults="false") public static final String IGNITE_SQL_PARSER_DISABLE_H2_FALLBACK
@SystemProperty(value="Disables SQL system views") public static final String IGNITE_SQL_DISABLE_SYSTEM_VIEWS
@SystemProperty(value="SQL retry timeout in milliseconds", type=java.lang.Long.class, defaults="30 seconds") public static final String IGNITE_SQL_RETRY_TIMEOUT
@SystemProperty(value="Enables backward compatible handling of UUID through DDL") public static final String IGNITE_SQL_UUID_DDL_BYTE_FORMAT
@Deprecated @SystemProperty(value="Enable memory quotas per JDBC connection") public static final String IGNITE_SQL_ENABLE_CONNECTION_MEMORY_QUOTA
SecurityPermission.SET_QUERY_MEMORY_QUOTA
.@SystemProperty(value="Enables subquery rewriting optimization. If enabled, subquery will be rewritten to JOIN where possible", defaults="true") public static final String IGNITE_ENABLE_SUBQUERY_REWRITE_OPTIMIZATION
true
.@SystemProperty(value="Maximum size for affinity assignment history", type=java.lang.Integer.class, defaults="25") public static final String IGNITE_AFFINITY_HISTORY_SIZE
@SystemProperty(value="Minimum size for affinity assignment history", type=java.lang.Integer.class, defaults="2") public static final String IGNITE_MIN_AFFINITY_HISTORY_SIZE
@SystemProperty(value="Maximum size for discovery messages history", type=java.lang.Integer.class, defaults="500") public static final String IGNITE_DISCOVERY_HISTORY_SIZE
@SystemProperty(value="Maximum number of discovery message history used to support client reconnect", type=java.lang.Integer.class, defaults="512") public static final String IGNITE_DISCOVERY_CLIENT_RECONNECT_HISTORY_SIZE
@SystemProperty(value="Enables logging a warning message when metrics quantity exceeded a specified number", type=java.lang.Integer.class, defaults="500") public static final String IGNITE_DISCOVERY_METRICS_QNT_WARN
@SystemProperty(value="Time interval in milliseconds that indicates client reconnect throttle must be reset to zero", type=java.lang.Long.class, defaults="120000") public static final String CLIENT_THROTTLE_RECONNECT_RESET_TIMEOUT_INTERVAL
@SystemProperty(value="Number of cache operation retries in case of topology exceptions", type=java.lang.Integer.class, defaults="100") public static final String IGNITE_CACHE_RETRIES_COUNT
@SystemProperty(value="Enables logging thread dump in case of partition exchange timeout") public static final String IGNITE_THREAD_DUMP_ON_EXCHANGE_TIMEOUT
true
then Ignite will log thread dump in case of partition exchange timeout.@SystemProperty(value="Enables logging thread dump in case of partition exchange timeout", defaults="false") public static final String IGNITE_IO_DUMP_ON_TIMEOUT
@SystemProperty(value="Enables diagnostic flag", defaults="true") public static final String IGNITE_DIAGNOSTIC_ENABLED
@SystemProperty(value="Cache operations that take more time than value of this property will be output to log. Set to 0 to disable", type=java.lang.Long.class, defaults="60000") public static final String IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT
0
to disable.@SystemProperty(value="Upper time limit between long running/hanging operations debug dumps in milliseconds", type=java.lang.Long.class) public static final String IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT_LIMIT
@SystemProperty(value="JDBC driver cursor remove delay in milliseconds", type=java.lang.Long.class, defaults="10 minutes") public static final String IGNITE_JDBC_DRIVER_CURSOR_REMOVE_DELAY
@SystemProperty(value="Long-long offheap map load factor", type=java.lang.Float.class, defaults="2.5") public static final String IGNITE_LONG_LONG_HASH_MAP_LOAD_FACTOR
@SystemProperty(value="Maximum number of nested listener calls before listener notification becomes asynchronous", type=java.lang.Integer.class, defaults="5") public static final String IGNITE_MAX_NESTED_LISTENER_CALLS
@SystemProperty(value="Enables local store keeps primary only. Backward compatibility flag") public static final String IGNITE_LOCAL_STORE_KEEPS_PRIMARY_ONLY
@SystemProperty(value="Manages OptimizedMarshaller behavior of serialVersionUID computation for Serializable classes") public static final String IGNITE_OPTIMIZED_MARSHALLER_USE_DEFAULT_SUID
@SystemProperty(value="Manages type of serialization mechanism for String that is marshalled/unmarshalled by BinaryMarshaller. Should be used for cases when a String contains a surrogate symbol without its pair one. This is frequently used in algorithms that encrypts data in String format") public static final String IGNITE_BINARY_MARSHALLER_USE_STRING_SERIALIZATION_VER_2
String
that is marshalled/unmarshalled by BinaryMarshaller.
Should be used for cases when a String contains a surrogate symbol without its pair one. This is frequently used
in algorithms that encrypts data in String format.@SystemProperty(value="Path to the file that contains list of classes allowed to safe deserialization", type=java.lang.String.class) public static final String IGNITE_MARSHALLER_WHITELIST
@SystemProperty(value="Path to the file that contains list of classes disallowed to safe deserialization", type=java.lang.String.class) public static final String IGNITE_MARSHALLER_BLACKLIST
@SystemProperty(value="Enables default selected keys set to be used inside GridNioServer which lead to some extra garbage generation when processing selected keys. Should be switched to true if there are any problems in communication layer") public static final String IGNITE_NO_SELECTOR_OPTS
true
, then default selected keys set is used inside
GridNioServer
which lead to some extra garbage generation when
processing selected keys.
Default value is false
. Should be switched to true
if there are
any problems in communication layer.
@SystemProperty(value="Period in milliseconds between calls of the SQL statements cache cleanup task. Cleanup tasks clears cache for terminated threads and for threads which did not perform SQL queries within timeout configured via IGNITE_H2_INDEXING_CACHE_THREAD_USAGE_TIMEOUT property", type=java.lang.Long.class, defaults="10 seconds") public static final String IGNITE_H2_INDEXING_CACHE_CLEANUP_PERIOD
Cleanup tasks clears cache for terminated threads and for threads which did not perform SQL queries within
timeout configured via IGNITE_H2_INDEXING_CACHE_THREAD_USAGE_TIMEOUT
property.
Default value is 10,000ms
.
@SystemProperty(value="Timeout in milliseconds after which thread\'s SQL statements cache is cleared by cleanup task if the thread does not perform any query", type=java.lang.Long.class, defaults="10 minutes") public static final String IGNITE_H2_INDEXING_CACHE_THREAD_USAGE_TIMEOUT
Default value is 600,000ms
.
@SystemProperty(value="Enables backward compatibility of StreamTransformer.from(CacheEntryProcessor) method. If the property is true, then the wrapped CacheEntryProcessor won\'t be able to be loaded over P2P class loading. If the property is false, then another implementation of StreamTransformer will be returned, that fixes P2P class loading for CacheEntryProcessor, but it will be incompatible with old versions of Ignite") public static final String IGNITE_STREAM_TRANSFORMER_COMPATIBILITY_MODE
StreamTransformer.from(CacheEntryProcessor)
method.
If the property is true
, then the wrapped CacheEntryProcessor
won't be able to be loaded over
P2P class loading.
If the property is false
, then another implementation of StreamTransformer
will be returned,
that fixes P2P class loading for CacheEntryProcessor
, but it will be incompatible with old versions
of Ignite.
@Deprecated @SystemProperty(value="If enabled then tree-based data structures - TreeMap and TreeSet - will not be wrapped into special holders introduced to overcome serialization issue caused by missing Comparable interface on BinaryObject") public static final String IGNITE_BINARY_DONT_WRAP_TREE_STRUCTURES
true
tree-based data structures - TreeMap
and TreeSet
- will not be
wrapped into special holders introduced to overcome serialization issue caused by missing Comparable
interface on BinaryObject
.
@SystemProperty(value="Enables consistent ID to calculate by host name, without port, and you can use only one node for host in cluster") public static final String IGNITE_CONSISTENT_ID_BY_HOST_WITHOUT_PORT
true
, for consistent id will calculate by host name, without port, and you can use
only one node for host in cluster.@SystemProperty(value="Consistent ID of Ignite node. Value of the system property will overwrite matched property IgniteConfiguration.setConsistentId(Serializable) in configuration", type=java.lang.String.class) public static final String IGNITE_OVERRIDE_CONSISTENT_ID
Value of the system property will overwrite matched property
IgniteConfiguration.setConsistentId(Serializable)
in configuration.
@SystemProperty(value="Ignores local address\'s hostname if IGNITE_LOCAL_HOST is defined when resolving local node\'s addresses", defaults="true") public static final String IGNITE_IGNORE_LOCAL_HOST_NAME
If set to true
and IGNITE_LOCAL_HOST
is defined then
IgniteUtils.resolveLocalAddresses(java.net.InetAddress)
will not add hostname of local address to the list of node's addresses.
Defaults to true
.
@SystemProperty(value="IO balance period in milliseconds", type=java.lang.Long.class, defaults="5000") public static final String IGNITE_IO_BALANCE_PERIOD
@SystemProperty(value="Enables fields to be written by BinaryMarshaller in sorted order. By default, the natural order is used") public static final String IGNITE_BINARY_SORT_OBJECT_FIELDS
true
fields are written by BinaryMarshaller in sorted order. Otherwise
the natural order is used.
NOTICE: Should be the default in Apache Ignite 3.0
@SystemProperty(value="Whether Ignite can access unaligned memory addresses. Defaults to false, meaning that unaligned access will be performed only on x86 architecture") public static final String IGNITE_MEMORY_UNALIGNED_ACCESS
Defaults to false
, meaning that unaligned access will be performed only on x86 architecture.
@SystemProperty(value="When unsafe memory copy if performed below this threshold, Ignite will do it on per-byte basis instead of calling to Unsafe.copyMemory(). 0 disables threshold", type=java.lang.Long.class, defaults="0") public static final String IGNITE_MEMORY_PER_BYTE_COPY_THRESHOLD
Defaults to 0, meaning that threshold is disabled.
@Deprecated @SystemProperty(value="If enabled BinaryObject will be unwrapped before passing to IndexingSpi to preserve old behavior query processor with IndexingSpi") public static final String IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI
true
BinaryObject will be unwrapped before passing to IndexingSpi to preserve
old behavior query processor with IndexingSpi.
@SystemProperty(value="Maximum payload size in bytes for H2TreeIndex. 0 means that inline index store is disabled", type=java.lang.Integer.class, defaults="10") public static final String IGNITE_MAX_INDEX_PAYLOAD_SIZE
H2TreeIndex
.
Defaults to 0
, meaning that inline index store is disabled.
@Deprecated @SystemProperty(value="Time interval for calculating rebalance rate statistics, in milliseconds", type=java.lang.Integer.class, defaults="60000") public static final String IGNITE_REBALANCE_STATISTICS_TIME_INTERVAL
MetricsMxBean.configureHitRateMetric(String, long)
instead.@SystemProperty(value="When cache has entries with expired TTL, each user operation will also remove this amount of expired entries", type=java.lang.Integer.class, defaults="5") public static final String IGNITE_TTL_EXPIRE_BATCH_SIZE
5
. Setting the value to 0
will disable this behavior.@SystemProperty(value="Indexing discovery history size. Protects from duplicate messages maintaining the list of IDs of recently arrived discovery messages", type=java.lang.Integer.class, defaults="1000") public static final String IGNITE_INDEXING_DISCOVERY_HISTORY_SIZE
Defaults to 1000
.
@SystemProperty(value="Cache start size for on-heap maps", type=java.lang.Integer.class, defaults="4096") public static final String IGNITE_CACHE_START_SIZE
@SystemProperty(value="Enables local start all existing caches on client node start") public static final String IGNITE_START_CACHES_ON_JOIN
@SystemProperty(value="Skip CRC calculation flag") public static final String IGNITE_PDS_SKIP_CRC
@Deprecated @SystemProperty(value="PDS partition destroy checkpoint delay", type=java.lang.Integer.class) public static final String IGNITE_PDS_PARTITION_DESTROY_CHECKPOINT_DELAY
@Deprecated @SystemProperty(value="WAL rebalance threshold", type=java.lang.Integer.class, defaults="500") public static final String IGNITE_PDS_WAL_REBALANCE_THRESHOLD
GridCacheDatabaseSharedManager.HISTORICAL_REBALANCE_THRESHOLD_DMS_KEY
.@SystemProperty(value="Prefer historical rebalance if there\'s enough history regardless off all heuristics. This property is intended for integration or performance tests") public static final String IGNITE_PREFER_WAL_REBALANCE
false
.@SystemProperty(value="Threshold of the checkpoint quantity since the last earliest checkpoint map snapshot. After this thresold is reached, a snapshot of the earliest checkpoint map will be captured", type=java.lang.Integer.class, defaults="5") public static final String IGNITE_CHECKPOINT_MAP_SNAPSHOT_THRESHOLD
5
.@SystemProperty(value="Ignite page memory concurrency level", type=java.lang.Integer.class) public static final String IGNITE_OFFHEAP_LOCK_CONCURRENCY_LEVEL
@SystemProperty(value="Enables Ignite to switch to compatibility mode with versions that don\'t support service security permissions. In this case security permissions will be ignored (if they set). Default is false, which means that service security permissions will be respected") public static final String IGNITE_SECURITY_COMPATIBILITY_MODE
true
, Ignite switches to compatibility mode with versions that don't
support service security permissions. In this case security permissions will be ignored
(if they set).
Default is false
, which means that service security permissions will be respected.
@SystemProperty(value="Ignite cluster name. Defaults to utility cache deployment ID", type=java.lang.String.class) public static final String IGNITE_CLUSTER_NAME
Defaults to utility cache deployment ID..
@SystemProperty(value="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. This timeout in milliseconds specifies how long to wait after client cache start/close before sending this message. If during this timeout another client cache changed, these events are combined into single message", type=java.lang.Long.class, defaults="10000") public static final String IGNITE_CLIENT_CACHE_CHANGE_MESSAGE_TIMEOUT
ClusterGroup.forCacheNodes(String)
API. This timeout specifies how long to wait
after client cache start/close before sending this message. If during this timeout another client
cache changed, these events are combined into single message.
Default is 10 seconds.
@SystemProperty(value="If a partition release future completion time during an exchange exceeds this threshold (in milliseconds), the contents of the future will be dumped to the log on exchange. 0 means disabled", type=java.lang.Integer.class, defaults="0") public static final String IGNITE_PARTITION_RELEASE_FUTURE_DUMP_THRESHOLD
0
(disabled).@SystemProperty(value="This property specifies the maximum number of futures that are included into diagnostic message", type=java.lang.Integer.class, defaults="10") public static final String IGNITE_PARTITION_RELEASE_FUTURE_WARN_LIMIT
10
.@SystemProperty(value="Enables node to forcible fail a remote node when it fails to establish a communication connection") public static final String IGNITE_ENABLE_FORCIBLE_NODE_KILL
@SystemProperty(value="If the property is set, coincidence of client identifier and subject is required when security is enabled", defaults="false") public static final String IGNITE_CHECK_SENDER_NODE_SUBJECT
Default value is fasle.
@SystemProperty(value="If the property is set, client nodes should have explicitly rights to access to system cache", defaults="false") public static final String IGNITE_SECURITY_FOR_SYS_CACHE_ENABLED
Default value is fasle.
@SystemProperty(value="Tasks stealing will be started if tasks queue size per data-streamer thread exceeds this threshold", type=java.lang.Integer.class, defaults="4") public static final String IGNITE_DATA_STREAMING_EXECUTOR_SERVICE_TASKS_STEALING_THRESHOLD
Default value is 4
.
@SystemProperty(value="If this property is set, then Ignite will use Async File IO factory by default", defaults="true") public static final String IGNITE_USE_ASYNC_FILE_IO_FACTORY
@SystemProperty(value="Max amount of remembered errors for GridLogThrottle", type=java.lang.Integer.class, defaults="128") public static final String IGNITE_LOG_THROTTLE_CAPACITY
GridLogThrottle
.@SystemProperty(value="Checkpoint throttling policy", type=java.lang.String.class) public static final String IGNITE_OVERRIDE_WRITE_THROTTLING_ENABLED
DataStorageConfiguration.isWriteThrottlingEnabled()
will be overridden to true
regardless the initial value in the configuration.@SystemProperty(value="WAL serializer version", type=java.lang.Integer.class, defaults="2") public static final String IGNITE_WAL_SERIALIZER_VERSION
@SystemProperty(value="WAL segment sync timeout in milliseconds", type=java.lang.Long.class, defaults="500") public static final String IGNITE_WAL_SEGMENT_SYNC_TIMEOUT
@SystemProperty(value="Enables usage of legacy node comparator (based on node order)") public static final String IGNITE_USE_LEGACY_NODE_COMPARATOR
false
.@SystemProperty(value="Enables usage of the mapped byte buffer", defaults="true") public static final String IGNITE_WAL_MMAP
true
and false
.@SystemProperty(value="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. This option also enables compatible folder generation mode as it was before 2.3") public static final String IGNITE_DATA_STORAGE_FOLDER_BY_CONSISTENT_ID
true
, Data store folders are generated only by consistent id, and no consistent ID will be
set based on existing data store folders. This option also enables compatible folder generation mode as it was
before 2.3.@SystemProperty(value="Disables JVM pause detector") public static final String IGNITE_JVM_PAUSE_DETECTOR_DISABLED
@SystemProperty(value="JVM pause detector precision", type=java.lang.Integer.class, defaults="50") public static final String IGNITE_JVM_PAUSE_DETECTOR_PRECISION
@SystemProperty(value="JVM pause detector threshold", type=java.lang.Integer.class, defaults="500") public static final String IGNITE_JVM_PAUSE_DETECTOR_THRESHOLD
@SystemProperty(value="JVM pause detector last events count", type=java.lang.Integer.class, defaults="20") public static final String IGNITE_JVM_PAUSE_DETECTOR_LAST_EVENTS_COUNT
@SystemProperty(value="Enables WAL debug log on recovery") public static final String IGNITE_WAL_DEBUG_LOG_ON_RECOVERY
false
.@SystemProperty(value="Number of checkpoint history entries held in memory", type=java.lang.Integer.class, defaults="100") public static final String IGNITE_PDS_MAX_CHECKPOINT_MEMORY_HISTORY_SIZE
@SystemProperty(value="Enables logging in GridClient") public static final String IGNITE_GRID_CLIENT_LOG_ENABLED
true
enable logging in GridClient
.@SystemProperty(value="Enables direct IO. Direct IO enabled only if JAR file with corresponding feature is available in classpath and OS and filesystem settings allows to enable this mode", defaults="true") public static final String IGNITE_DIRECT_IO_ENABLED
true
, direct IO may be enabled. Direct IO enabled only if JAR file with corresponding
feature is available in classpath and OS and filesystem settings allows to enable this mode.
Default is true
.@SystemProperty(value="Enables development environments warnings") public static final String IGNITE_DEV_ONLY_LOGGING_DISABLED
true
, warnings that are intended for development environments and not for production
(such as coding mistakes in code using Ignite) will not be logged.@SystemProperty(value="When set to true (default), pages are written to page store without holding segment lock (with delay). Because other thread may require exactly the same page to be loaded from store, reads are protected by locking", defaults="true") public static final String IGNITE_DELAYED_REPLACED_PAGE_WRITE
true
(default), pages are written to page store without holding segment lock (with delay).
Because other thread may require exactly the same page to be loaded from store, reads are protected by locking.@SystemProperty(value="When set to true, WAL implementation with dedicated worker will be used even in FSYNC mode") public static final String IGNITE_WAL_FSYNC_WITH_DEDICATED_WORKER
true
, WAL implementation with dedicated worker will be used even in FSYNC mode.
Default is false
.@SystemProperty(value="When set to true, on-heap cache cannot be enabled - see CacheConfiguration.setOnheapCacheEnabled(boolean)") public static final String IGNITE_DISABLE_ONHEAP_CACHE
true
, on-heap cache cannot be enabled - see
CacheConfiguration.setOnheapCacheEnabled(boolean)
.
Default is false
.@SystemProperty(value="When set to false, loaded pages implementation is switched to previous version of implementation, FullPageIdTable. True value enables \'Robin Hood hashing: backward shift deletion\'", defaults="true") public static final String IGNITE_LOADED_PAGES_BACKWARD_SHIFT_MAP
false
, loaded pages implementation is switched to previous version of implementation,
FullPageIdTable. True
value enables 'Robin Hood hashing: backward shift deletion'.
Default is true
.@SystemProperty(value="Percentage of archive size for checkpoint trigger", type=java.lang.Double.class, defaults="0.75") public static final String IGNITE_CHECKPOINT_TRIGGER_ARCHIVE_SIZE_PERCENTAGE
@SystemProperty(value="Percentage of WAL archive size to calculate threshold since which removing of old archive should be started", type=java.lang.Double.class, defaults="0.5") public static final String IGNITE_THRESHOLD_WAL_ARCHIVE_SIZE_PERCENTAGE
DataStorageConfiguration.setMinWalArchiveSize(long)
.@SystemProperty(value="Threshold time (in millis) to print warning to log if waiting for next wal segment took longer than the threshold", type=java.lang.Long.class, defaults="1000 milliseconds") public static final String IGNITE_THRESHOLD_WAIT_TIME_NEXT_WAL_SEGMENT
@SystemProperty(value="Count of WAL compressor worker threads", type=java.lang.Integer.class, defaults="4") public static final String IGNITE_WAL_COMPRESSOR_WORKER_THREAD_CNT
@SystemProperty(value="Enables read load balancing, that means \'get\' requests will be distributed between primary and backup nodes if it is possible and CacheConfiguration.isReadFromBackup() is true. ", defaults="true") public static final String IGNITE_READ_LOAD_BALANCING
CacheConfiguration.isReadFromBackup()
is true
.
Default is true
.@SystemProperty(value="Number of repetitions to capture a lock in the B+Tree", type=java.lang.Integer.class, defaults="1000") public static final String IGNITE_BPLUS_TREE_LOCK_RETRIES
@SystemProperty(value="Amount of memory reserved in the heap at node start, which can be dropped to increase the chances of success when handling OutOfMemoryError", type=java.lang.Integer.class, defaults="65536") public static final String IGNITE_FAILURE_HANDLER_RESERVE_BUFFER_SIZE
64kb
.@SystemProperty(value="The threshold of uneven distribution above which partition distribution will be logged", type=java.lang.Float.class, defaults="50.0") public static final String IGNITE_PART_DISTRIBUTION_WARN_THRESHOLD
@SystemProperty(value="When set to false, WAL will not be automatically disabled during rebalancing if there is no partition in OWNING state", defaults="true") public static final String IGNITE_DISABLE_WAL_DURING_REBALANCING
false
, WAL will not be automatically disabled during rebalancing if there is no partition in
OWNING state.
Default is true
.@SystemProperty(value="When property is set false each next exchange will try to compare with previous. If last rebalance is equivalent with new possible one, new rebalance does not trigger. Set the property true and each exchange will try to trigger new rebalance") public static final String IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION
false
each next exchange will try to compare with previous.
If last rebalance is equivalent with new possible one, new rebalance does not trigger.
Set the property true
and each exchange will try to trigger new rebalance.
Default is false
.@SystemProperty(value="Timeout for TCP client recovery descriptor reservation in milliseconds", type=java.lang.Long.class, defaults="5000") public static final String IGNITE_NIO_RECOVERY_DESCRIPTOR_RESERVATION_TIMEOUT
@SystemProperty(value="Enables Ignite to skip partitions sizes check on partition validation after rebalance has finished. Partitions sizes may differs on nodes when Expiry Policy is in use and it is ok due to lazy entry eviction mechanics. There is no need to disable partition size validation either in normal case or when expiry policy is configured for cache. But it should be disabled manually when policy is used on per entry basis to hint Ignite to skip this check") public static final String IGNITE_SKIP_PARTITION_SIZE_VALIDATION
true
, Ignite will skip partitions sizes check on partition validation after rebalance has finished.
Partitions sizes may differs on nodes when Expiry Policy is in use and it is ok due to lazy entry eviction mechanics.
There is no need to disable partition size validation either in normal case or when expiry policy is configured for cache.
But it should be disabled manually when policy is used on per entry basis to hint Ignite to skip this check.
Default is false
.@SystemProperty(value="Enables threads dumping on critical node failure") public static final String IGNITE_DUMP_THREADS_ON_FAILURE
true
.@SystemProperty(value="Throttling time out for thread dump generation during failure handling in milliseconds. Default is failure detection timeout. 0 or negative value - throttling is disabled", type=java.lang.Long.class) public static final String IGNITE_DUMP_THREADS_ON_FAILURE_THROTTLING_TIMEOUT
0
or negative value - throttling is disabled.@Deprecated @SystemProperty(value="Throttling timeout in milliseconds which avoid excessive PendingTree access on unwind if there is nothing to clean yet", type=java.lang.Long.class) public static final String IGNITE_UNWIND_THROTTLING_TIMEOUT
@SystemProperty(value="Threshold in seconds for throttling operations logging", type=java.lang.Integer.class, defaults="10") public static final String IGNITE_THROTTLE_LOG_THRESHOLD
@Deprecated @SystemProperty(value="Number of concurrent operation for evict partitions", type=java.lang.Integer.class) public static final String IGNITE_EVICTION_PERMITS
@SystemProperty(value="When set to true, Ignite will allow execute DML operation (MERGE|INSERT|UPDATE|DELETE) within transaction for non MVCC mode") public static final String IGNITE_ALLOW_DML_INSIDE_TRANSACTION
true
, Ignite will allow execute DML operation (MERGE|INSERT|UPDATE|DELETE)
within transaction for non MVCC mode.
Default is false
.@SystemProperty(value="Timeout between ZooKeeper client retries in milliseconds", type=java.lang.Long.class, defaults="2 seconds") public static final String IGNITE_ZOOKEEPER_DISCOVERY_RETRY_TIMEOUT
@SystemProperty(value="Number of attempts to reconnect to ZooKeeper", type=java.lang.Integer.class, defaults="10") public static final String IGNITE_ZOOKEEPER_DISCOVERY_MAX_RETRY_COUNT
@SystemProperty(value="Maximum number for cached MVCC transaction updates. This caching is used for continuous query with MVCC caches", type=java.lang.Integer.class, defaults="20000") public static final String IGNITE_MVCC_TX_SIZE_CACHING_THRESHOLD
@SystemProperty(value="Try reuse memory on deactivation") public static final String IGNITE_REUSE_MEMORY_ON_DEACTIVATE
@SystemProperty(value="Maximum inactivity period for system worker in milliseconds. When this value is exceeded, worker is considered blocked with consequent critical failure handler invocation", type=java.lang.Long.class) public static final String IGNITE_SYSTEM_WORKER_BLOCKED_TIMEOUT
@SystemProperty(value="Timeout for checkpoint read lock acquisition in milliseconds", type=java.lang.Long.class) public static final String IGNITE_CHECKPOINT_READ_LOCK_TIMEOUT
@SystemProperty(value="Timeout for waiting schema update if schema was not found for last accepted version in milliseconds", type=java.lang.Long.class, defaults="30000") public static final String IGNITE_WAIT_SCHEMA_UPDATE
@Deprecated @SystemProperty(value="Overrides CacheConfiguration.getRebalanceThrottle configuration property for all caches in milliseconds. 0 by default, which means that override is disabled", type=java.lang.Long.class, defaults="0") public static final String IGNITE_REBALANCE_THROTTLE_OVERRIDE
IgniteConfiguration.getRebalanceThrottle()
instead.CacheConfiguration.getRebalanceThrottle()
configuration property for all caches.
0
by default, which means that override is disabled.@SystemProperty(value="Enables start caches in parallel", defaults="true") public static final String IGNITE_ALLOW_START_CACHES_IN_PARALLEL
true
.@SystemProperty(value="For test purposes only. Force Mvcc mode") public static final String IGNITE_FORCE_MVCC_MODE_IN_TESTS
@SystemProperty(value="Allows to log additional information about all restored partitions after binary and logical recovery phases") public static final String IGNITE_RECOVERY_VERBOSE_LOGGING
true
.@SystemProperty(value="Disables cache interceptor triggering in case of conflicts") public static final String IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT
false
.@SystemProperty(value="Disk page compression - CacheConfiguration#setDiskPageCompression", type=DiskPageCompression.class) public static final String IGNITE_DEFAULT_DISK_PAGE_COMPRESSION
@SystemProperty(value="Storage page size - DataStorageConfiguration#setPageSize", type=java.lang.Integer.class) public static final String IGNITE_DEFAULT_DATA_STORAGE_PAGE_SIZE
storage page size
.@SystemProperty(value="Manages the type of the implementation of the service processor (implementation of the IgniteServices). All nodes in the cluster must have the same value of this property. If the property is true then event-driven implementation of the service processor will be used. If the property is false then internal cache based implementation of service processor will be used", defaults="true") public static final String IGNITE_EVENT_DRIVEN_SERVICE_PROCESSOR_ENABLED
IgniteServices
).
All nodes in the cluster must have the same value of this property.
If the property is true
then event-driven implementation of the service processor will be used.
If the property is false
then internal cache based implementation of service processor will be used.
Default is true
.@SystemProperty(value="When set to true, cache metrics are not included into the discovery metrics update message (in this case message contains only cluster metrics). By default cache metrics are included into the message and calculated each time the message is sent. Cache metrics sending can also be turned off by disabling statistics per each cache, but in this case some cache metrics will be unavailable via JMX too") public static final String IGNITE_DISCOVERY_DISABLE_CACHE_METRICS_UPDATE
true
, cache metrics are not included into the discovery metrics update message (in this
case message contains only cluster metrics). By default cache metrics are included into the message and
calculated each time the message is sent.
Cache metrics sending can also be turned off by disabling statistics per each cache, but in this case some cache metrics will be unavailable via JMX too.
@SystemProperty(value="Maximum number of different partitions to be extracted from between expression within sql query. In case of limit exceeding all partitions will be used", type=java.lang.Integer.class, defaults="16") public static final String IGNITE_SQL_MAX_EXTRACTED_PARTS_FROM_BETWEEN
@SystemProperty(value="Maximum amount of bytes that can be stored in history of DistributedMetaStorage updates", type=java.lang.Long.class, defaults="104857600") public static final String IGNITE_GLOBAL_METASTORAGE_HISTORY_MAX_BYTES
DistributedMetaStorage
updates.@SystemProperty(value="Size threshold to allocate and retain additional HashMap to improve contains() which leads to extra memory consumption", type=java.lang.Integer.class, defaults="5") public static final String IGNITE_AFFINITY_BACKUPS_THRESHOLD
@SystemProperty(value="Disables memory optimization: BitSets instead of HashSets to store partitions. When number of backups per partitions is > IGNITE_AFFINITY_BACKUPS_THRESHOLD we use HashMap to improve contains() which leads to extra memory consumption, otherwise we use view on the list of cluster nodes to reduce memory consumption on redundant data structures") public static final String IGNITE_DISABLE_AFFINITY_MEMORY_OPTIMIZATION
@SystemProperty(value="Limit the maximum number of objects in memory during the recovery procedure", type=java.lang.Integer.class) public static final String IGNITE_RECOVERY_SEMAPHORE_PERMITS
@SystemProperty(value="Maximum size of history of server nodes (server node IDs) that ever joined to current topology", type=java.lang.Integer.class, defaults="50") public static final String IGNITE_NODE_IDS_HISTORY_SIZE
@SystemProperty(value="Maximum number of diagnostic warning messages per category, when waiting for PME", type=java.lang.Integer.class, defaults="10") public static final String IGNITE_DIAGNOSTIC_WARN_LIMIT
@SystemProperty(value="Enables triggering failure handler for node if unrecoverable partition inconsistency is discovered during partition update counters exchange") public static final String IGNITE_FAIL_NODE_ON_UNRECOVERABLE_PARTITION_INCONSISTENCY
@SystemProperty(value="Allow use composite _key, _val columns at the INSERT/UPDATE/MERGE statements") public static final String IGNITE_SQL_ALLOW_KEY_VAL_UPDATES
@SystemProperty(value="Forcibly fills missing columns belonging to the primary key with nulls or default values if those have been specified", defaults="false") public static final String IGNITE_SQL_FILL_ABSENT_PK_WITH_DEFAULTS
@SystemProperty(value="Interval between logging of time of next auto-adjust in milliseconds", type=java.lang.Long.class) public static final String IGNITE_BASELINE_AUTO_ADJUST_LOG_INTERVAL
@SystemProperty(value="Starting from this number of dirty pages in checkpoint, array will be sorted with Arrays.parallelSort(Comparable[]) in case of CheckpointWriteOrder.SEQUENTIAL", type=java.lang.Integer.class, defaults="524288") public static final String CHECKPOINT_PARALLEL_SORT_THRESHOLD
Arrays.parallelSort(Comparable[])
in case of CheckpointWriteOrder.SEQUENTIAL
.@SystemProperty(value="Keep static cache configuration even if stored cache data differs from the static config. When this property is set, static cache configuration will override persisted configuration. DDL operations are not allowed when this system property is set") public static final String IGNITE_KEEP_STATIC_CACHE_CONFIGURATION
@SystemProperty(value="Enable backward compatible to use \'IGNITE\' as SQL system schema") public static final String IGNITE_SQL_SYSTEM_SCHEMA_NAME_IGNITE
@SystemProperty(value="Shows if dump requests from local node to near node are allowed, when long running transaction is found. If allowed, the compute request to near node will be made to get thread dump of transaction owner thread", defaults="true") public static final String IGNITE_TX_OWNER_DUMP_REQUESTS_ALLOWED
@SystemProperty(value="Defines factory class for H2 LocalResult", type=java.lang.String.class, defaults="org.apache.ignite.internal.processors.query.h2.H2LocalResultFactory") public static final String IGNITE_H2_LOCAL_RESULT_FACTORY
@SystemProperty(value="Defines default memory reservation block size", type=java.lang.Long.class, defaults="524288") public static final String IGNITE_SQL_MEMORY_RESERVATION_BLOCK_SIZE
@SystemProperty(value="Page lock tracker type. -1 - Disable lock tracking. 1 - HEAP_STACK. 2 - HEAP_LOG. 3 - OFF_HEAP_STACK. 4 - OFF_HEAP_LOG", type=java.lang.Integer.class, defaults="2") public static final String IGNITE_PAGE_LOCK_TRACKER_TYPE
@SystemProperty(value="Capacity in pages for storing in page lock tracker strucuture", type=java.lang.Integer.class, defaults="512") public static final String IGNITE_PAGE_LOCK_TRACKER_CAPACITY
@SystemProperty(value="Page lock tracker thread for checking hangs threads interval", type=java.lang.Integer.class, defaults="60000") public static final String IGNITE_PAGE_LOCK_TRACKER_CHECK_INTERVAL
@SystemProperty(value="Enables threads locks dumping on critical node failure", defaults="true") public static final String IGNITE_DUMP_PAGE_LOCK_ON_FAILURE
true
.@SystemProperty(value="Scan the classpath on startup and log all the files containing in it", defaults="true") public static final String IGNITE_LOG_CLASSPATH_CONTENT_ON_STARTUP
@SystemProperty(value="Maximum size of table (rows count) when temporary hash index can be built on fly", type=java.lang.Integer.class, defaults="100000") public static final String IGNITE_HASH_JOIN_MAX_TABLE_SIZE
@SystemProperty(value="Enable hash join (create hash index on the fly) for query optimizer. When disabled hash join may be enabled only by index hint", defaults="false") public static final String IGNITE_ENABLE_HASH_JOIN
@SystemProperty(value="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 acquiring locks, preparing, committing, etc) and user time (time when client node runs some code while holding transaction and not waiting it). Equals 0 if not set. No long transactions are dumped in log if nor this parameter neither IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT is set", type=java.lang.Long.class) public static final String IGNITE_LONG_TRANSACTION_TIME_DUMP_THRESHOLD
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT
is set.@SystemProperty(value="The coefficient for samples of completed transactions that will be dumped in log. Must be float value between 0.0 and 1.0 inclusive", type=java.lang.Float.class) public static final String IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT
0.0
.@SystemProperty(value="The limit of samples of completed transactions that will be dumped in log per second, if IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT is above 0.0. Must be integer value greater than 0", type=java.lang.Integer.class, defaults="5") public static final String IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_PER_SECOND_LIMIT
IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT
is above 0.0
. Must be integer value
greater than 0
. Default value is 5
.@SystemProperty(value="Disables smart DR throttling", defaults="false") public static final String IGNITE_DISABLE_SMART_DR_THROTTLING
false
.@SystemProperty(value="Disables onheap caching of pages lists (free lists and reuse lists). If persistence is enabled changes to page lists are not stored to page memory immediately, they are cached in onheap buffer and flushes to page memory on a checkpoint. This property allows to disable such onheap caching") public static final String IGNITE_PAGES_LIST_DISABLE_ONHEAP_CACHING
@SystemProperty(value="The master key name that the node will use during the recovery. If a node was unavailable during a master key change process it won\'t be able to join to cluster with old the master key. Set up this property to re-encrypt cache keys on startup and join to cluster with the valid master key name", type=java.lang.String.class) public static final String IGNITE_MASTER_KEY_NAME_TO_CHANGE_BEFORE_STARTUP
If a node was unavailable during a master key change process it won't be able to join to cluster with old the master key. Set up this property to re-encrypt cache keys on startup and join to cluster with the valid master key name.
@SystemProperty(value="Disable group state lazy store. It means that group state won\'t be cached and will be read from wal every time", defaults="false") public static final String IGNITE_DISABLE_GRP_STATE_LAZY_STORE
CheckpointEntry
and will be
read from wal every time. Should be used for test purposes only.@SystemProperty(value="Enables extended logging of indexes create/rebuild process. Warning: enabling that option can lead to performance degradation of index creation, rebuilding and node restart") public static final String IGNITE_ENABLE_EXTRA_INDEX_REBUILD_LOGGING
false
.
Warning: enabling that option can lead to performance degradation of index creation, rebuilding and node
restart.@Deprecated @SystemProperty(value="Enables node to wait until all of its data is backed up before shutting down. Please note that it will completely prevent last node in cluster from shutting down if any caches exist that have backups configured") public static final String IGNITE_WAIT_FOR_BACKUPS_ON_SHUTDOWN
ShutdownPolicy
instead.@SystemProperty(value="Choose the index cost function. May be used to compatibility with old version\n The possible values: \"LAST\", \"COMPATIBLE_8_7_28\", \"COMPATIBLE_8_7_12\", \"COMPATIBLE_8_7_6\"", defaults="LAST") public static final String IGNITE_INDEX_COST_FUNCTION
@SystemProperty(value="Enables setting attribute value of TcpCommunicationSpi#ATTR_HOST_NAMES when value IgniteConfiguration#getLocalHost is ip, for backward compatibility") public static final String IGNITE_TCP_COMM_SET_ATTR_HOST_NAMES
ATTR_HOST_NAMES
when value getLocalHost
is ip, for backward
compatibility. By default, false
.@SystemProperty(value="When above zero, prints tx key collisions once per interval. Each transaction besides OPTIMISTIC SERIALIZABLE capture locks on all enlisted keys, for some reasons per key lock queue may rise. This property sets the interval during which statistics are collected", type=java.lang.Integer.class, defaults="1000") public static final String IGNITE_DUMP_TX_COLLISIONS_INTERVAL
@SystemProperty(value="Defines how many exchange futures are kept uncleared in the queue", type=java.lang.Integer.class, defaults="10") public static final String IGNITE_KEEP_UNCLEARED_EXCHANGE_FUTURES_LIMIT
@SystemProperty(value="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") public static final String IGNITE_DFLT_ALLOW_EMPTY_SYS_PERMISSIONS
SecurityPermissionSet.defaultAllowAll()
is set to true: if user's system permission set is empty,
all system actions will be prohibited.@SystemProperty(value="Defragmentation region size percentage of configured region size. This percentage will be calculated from largest configured region size and then proportionally subtracted from all configured regions", type=java.lang.Integer.class, defaults="60") public static final String IGNITE_DEFRAGMENTATION_REGION_SIZE_PERCENTAGE
@SystemProperty(value="If true, cache names will be validated not to contain characters which cause issues when persistence is used ({@code \\}, {@code /}, {@code \\0})", defaults="true") public static final String IGNITE_VALIDATE_CACHE_NAMES
true
, cache names will be validated not to contain characters which cause issues when persistence is used
(\
, /
, \0
). Default is true
.@SystemProperty(value="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. If this option is set to false, then tasks will not be started", defaults="true") public static final String IGNITE_EXECUTE_DURABLE_BACKGROUND_TASKS_ON_NODE_START_OR_ACTIVATE
false
, then tasks will not be started.@SystemProperty(value="Set to true only during the junit tests", defaults="false") public static final String IGNITE_TEST_ENV
@SystemProperty(value="Use TreeMap instead of HashMap to hold distinct values", defaults="false") public static final String IGNITE_SQL_DISTINCT_RESULTS_USE_TREE_MAP
false
. HashMap is used by default.@SystemProperty(value="Count of rows, being processed within a single checkpoint lock when indexes are rebuilt", type=java.lang.Integer.class, defaults="1000") public static final String IGNITE_INDEX_REBUILD_BATCH_SIZE
@SystemProperty(value="Enables additional check that sender of communication handshake message corresponds to the node id included in the message", defaults="false") public static final String IGNITE_CHECK_COMMUNICATION_HANDSHAKE_MESSAGE_SENDER
false
.@SystemProperty(value="Enables asserts instead of warning or error log messaged on check some internal invariants", defaults="false") public static final String IGNITE_STRICT_CONSISTENCY_CHECK
false
.@SystemProperty(value="Disable a maintenance task for removing storage folders", defaults="false") public static final String IGNITE_DISABLE_MAINTENANCE_CLEAR_FOLDER_TASK
@SystemProperty(value="Enables an allow overwrite mode for a data streamer", defaults="true") public static final String IGNITE_DATA_STREAMER_ALLOW_OVERWRITE
@SystemProperty(value="SSL handshake timeout, in milliseconds", type=java.lang.Long.class, defaults="3000 milliseconds") public static final String IGNITE_SSL_HANDSHAKE_TIMEOUT
@SystemProperty(value="This property allows reducing the number of internal notifications of thick clients when the cache-based implementation of the service framework is used", defaults="false") public static final String IGNITE_SERVICES_SET_REMOTE_FILTER_ON_START
IGNITE_EVENT_DRIVEN_SERVICE_PROCESSOR_ENABLED
.@SystemProperty(value="Node in maintenance mode will automatically shut down after all active maintenance would be completed", defaults="false") public static final String IGNITE_MAINTENANCE_AUTO_SHUTDOWN_AFTER_RECOVERY
@SystemProperty(value="Dumps latest WAL segments and related index and partition files on data corruption error", defaults="false") public static final String IGNITE_DUMP_PERSISTENCE_FILES_ON_DATA_CORRUPTION
@SystemProperty(value="Node in maintenance mode will shut down with specified JVM exit code", defaults="0") public static final String IGNITE_MAINTENANCE_MODE_EXIT_CODE
@SystemProperty(value="SSL unwrap timeout, in milliseconds", type=java.lang.Long.class, defaults="3000 milliseconds") public static final String IGNITE_SSL_UNWRAP_TIMEOUT
@SystemProperty(value="Packages list to expose in configuration view") public static final String IGNITE_CONFIGURATION_VIEW_PACKAGES
GridSystemViewManager
,
ConfigurationView
,
Constant Field Values@SystemProperty(value="Nodes will send messages with compacted topology history", defaults="true") public static final String IGNITE_COMPACTED_TOPOLOGY_HISTORY
public static <E extends Enum<E>> E getEnum(Class<E> enumCls, String name)
enumCls
- Enum type.name
- Name of the system property or environment variable.null
if the property is not set.public static <E extends Enum<E>> E getEnum(String name, E dflt)
name
- Name of the system property or environment variable.@Nullable public static @Nullable String getString(String name)
name
- Name of the system property or environment variable.null
if neither can be found for given name.@Nullable public static @Nullable String getString(String name, String dflt)
name
- Name of the system property or environment variable.dflt
- Default value.null
if neither can be found for given name.public static boolean getBoolean(String name)
boolean
using Boolean.valueOf()
method.name
- Name of the system property or environment variable.False
in case neither system property
nor environment variable with given name is found.public static boolean getBoolean(String name, boolean dflt)
boolean
using Boolean.valueOf()
method.name
- Name of the system property or environment variable.dflt
- Default value.public static int getInteger(String name, int dflt)
int
using Integer.parseInt()
method.name
- Name of the system property or environment variable.dflt
- Default value.public static float getFloat(String name, float dflt)
float
using Float.parseFloat()
method.name
- Name of the system property or environment variable.dflt
- Default value.public static long getLong(String name, long dflt)
long
using Long.parseLong()
method.name
- Name of the system property or environment variable.dflt
- Default value.public static double getDouble(String name, double dflt)
double
using Double.parseDouble()
method.name
- Name of the system property or environment variable.dflt
- Default value.public static UUID getUUID(String name, UUID dflt)
UUID
using UUID.fromString(java.lang.String)
method.name
- Name of the system property or environment variable.dflt
- Default value.public static Properties snapshot()
GridGain In-Memory Computing Platform : ver. 8.9.14 Release Date : November 5 2024