Please keep entries in this file in alphabetical order in order to facilitate merging!
Boolean#getBoolean(String)
Integer#getInteger(String)
Integer#getInteger(String, Integer)
Integer#getInteger(String, int)
Long#getLong(String)
Long#getLong(String, Long)
Long#getLong(String, long)
System#getProperties
System#getProperty(String)
System#getProperty(String, String)
gemfire.
to each
valid attribute name, then looks for a System property with that value. If
such a property name exists, it overrides any read from a property file or
any properties passed into the caller.
org.apache.geode.internal.cache.Oplog
looks for properties
of the form:
_UNIT_BUFF_SIZE
_MAX_POOL_SIZE
_WAIT_TIME
Integer (default is 60000)
See org.apache.geode.admin.internal.AdminDistributedSystemImpl#TIMEOUT_MS
.
TBA
Boolean (default is false)
See org.apache.geode.internal.AvailablePort
.
If true, an instance of java.util.Random
is used instead of
java.security.SecureRandom
to randomly select a port.
This property is available in case there is a performance issue involved with random port selection.
Integer (default is 2000)
See org.apache.geode.internal.AvailablePort#isPortAvailable
.
When establishing a locator, this sets the SO_TIMEOUT
characteristic on the UDP port that we attempt to test.
Units are in milliseconds.
See org.apache.geode.internal.cache.BridgeServerImpl.#VERBOSE
.
Enable verbose logging in the BridgeServer
Integer (default is 4)
See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#HANDSHAKE_POOL_SIZE
.
TBA
Integer (default is 100)
See org.apache.geode.internal.cache.tier.sockets.ServerConnection#maximumChunkSize
.
TBA
Integer (default is -1)
See org.apache.geode.internal.cache.tier.sockets.ServerConnection#MAX_INCOMING_DATA
.
Maximum number of concurrent incoming client message bytes that a bridge server will allow. Once a server is working on this number additional incoming client messages will wait until one of them completes or fails. The bytes are computed based in the size sent in the incoming msg header.
TBA
Integer (default is -1)
See org.apache.geode.internal.cache.tier.sockets.ServerConnection#MAX_INCOMING_MSGS
.
Maximum number of concurrent incoming client messages that a bridge server will allow. Once a server is working on this number additional incoming client messages will wait until one of them completes or fails.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#DEPRECATED_SELECTOR
.
TBA
Integer (default is 16)
See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#DEPRECATED_SELECTOR_POOL_SIZE
.
This system property is only used if max-threads == 0. This is for 5.0.2 backwards compatibility. @deprecated since 5.1 use cache-server max-threads instead
TBA
Integer (default is 32768)
See org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier#socketBufferSize
.
See org.apache.geode.internal.cache.tier.sockets.CacheClientUpdater#CacheClietnUpdater(String, EndpointImpl, List, LogWriter, boolean, DistributedSystem)
.
The size of the server-to-client communication socket buffers. This can be modified using the BridgeServer.SOCKET_BUFFER_SIZE system property.
TBA
Integer (default is 2900)
See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#acceptTimeout
.
Units are in milliseconds.
Test value for accept timeout
TBA
Integer (default is 1280)
See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl
constructor.
This is the TCP/IP "accept" backlog for client/server communications.
Integer (default is 59000)
See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#handshakeTimeout
.
Test value for handshake timeout. Note the capital S in "handShakeTimeout".
Units are in milliseconds.
TBA
Boolean (default is false)
See org.apache.geode.DataSerializer#DEBUG
TBA
Boolean (default is false)
See org.apache.geode.DataSerializer#DUMP_SERIALIZED
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.locks.DLockLogWriter#VERBOSE
.
Enables logging for this class.
Long (default is 10 * 1000)
See org.apache.geode.distributed.internal.InternalDistributedSystem#MAX_DISCONNECT_WAIT
.
This is how much time, in milliseconds to allow a disconnect listener to run before we interrupt it.
TBA
Integer (default is 80000)
See org.apache.geode.distributed.internal.DistributionManager#INCOMING_QUEUE_LIMIT
.
TBA
Integer (default is INCOMING_QUEUE_LIMIT * .75)
See org.apache.geode.distributed.internal.DistributionManager#INCOMING_QUEUE_THROTTLE
.
TBA
Integer: (default is 100 or 16 * number of processors, whichever is larger)
Maximum function execution threads.
See org.apache.geode.distributed.internal.DistributionManager#MAX_FE_THREADS
.
Integer (default is 200 or 32 * number of processors, whichever is larger)
See org.apache.geode.distributed.internal.DistributionManager#MAX_PR_THREADS
.
TBA
Integer (default is 20)
See org.apache.geode.distributed.internal.DistributionManager#MAX_SERIAL_QUEUE_THREAD
.
Max number of serial Queue executors, in case of multi-serial-queue executor
TBA
Integer (default is 1000)
See org.apache.geode.distributed.internal.DistributionManager#MAX_THREADS
.
TBA
Integer (default is Integer.MAX_VALUE)
See org.apache.geode.distributed.internal.DistributionManager#MAX_WAITING_THREADS
.
TBA
Integer (default is 2000)
See org.apache.geode.internal.cache.SearchLoadAndWriteProcessor#SMALL_BLOB_SIZE
.
TBA
Integer (default is 4096)
See org.apache.geode.distributed.internal.DistributionManager#PUSHER_QUEUE_SIZE
.
TBA
Integer (default is 50)
See org.apache.geode.distributed.internal.DistributionManager#PUSHER_THREADS
.
TBA
Integer (default is 40 * 1024 * 1024)
See org.apache.geode.distributed.internal.DistributionManager#SERIAL_QUEUE_BYTE_LIMIT
.
TBA
Integer (default is 20000)
See org.apache.geode.distributed.internal.DistributionManager#SERIAL_QUEUE_SIZE_LIMIT
.
TBA
Integer (default is SERIAL_QUEUE_SIZE_LIMIT * THROTTLE_PERCENT)
See org.apache.geode.distributed.internal.DistributionManager#SERIAL_QUEUE_THROTTLE
.
TBA
Integer (default is 75)
See org.apache.geode.distributed.internal.DistributionManager#THROTTLE_PERCENT
.
TBA
Integer (default is 15000)
See org.apache.geode.distributed.internal.DistributionManager#STARTUP_TIMEOUT
.
Units are in milliseconds. This is how long a Startup message waits before it declares the peer to be nonresponsive.
TBA
Long (default is -1)
See org.apache.geode.distributed.internal.DistributionManager#TIMEOUT
.
The number of milliseconds to wait for distribution-related things to happen */
TBA
Integer (default is 80 * 1024 * 1024)
See org.apache.geode.distributed.internal.DistributionManager#TOTAL_SERIAL_QUEUE_BYTE_LIMIT
.
TBA
Integer (default is SERIAL_QUEUE_BYTE_LIMIT * THROTTLE_PERCENT)
See org.apache.geode.distributed.internal.DistributionManager#TOTAL_SERIAL_QUEUE_THROTTLE
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.DistributionManager#VERBOSE
.
Enables certain additional (fine-level?) logging.
Boolean (default is false)
See org.apache.geode.distributed.internal.membership.gms.GMSMembershipManager#VERBOSE_VIEWS
.
Enables additional info-level logging
(see #addShunnedMember
and #addSurpriseMember
).
Boolean (default is false)
See org.apache.geode.distributed.internal.DistributionManager#INLINE_PROCESS
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.DistributionManager#sendStartupMessage
.
Fail distributed system join unless a startup response is received from all peers.
Boolean (default is false)
See org.apache.geode.distributed.internal.DistributionManager#MULTI_SERIAL_EXECUTORS
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.DistributionManager#SYNC_EVENTS
.
TBA
Boolean (default is false)
See org.apache.geode.cache.DynamicRegionFactory#DISABLE_PERSIST_BACKUP
.
TBA
Boolean (default is false)
See org.apache.geode.cache.DynamicRegionFactory#DISABLE_REGISTER_INTEREST
.
TBA
Long (default is 250)
See org.apache.geode.cache.DynamicRegionFactory#regionCreateSleepMillis
.
This controls the delay introduced to try and avoid any race conditions between propagation of newly created Dynamic Regions and the Entries put into them.
TBA
Integer (default is 5 * 60 * 1000)
See org.apache.geode.internal.cache.GatewayImpl.EventWrapper#EVENT_TIMEOUT
.
Units are in milliseconds.
TBA
Integer (default is 20)
See org.apache.geode.internal.cache.GatewayImpl.#MAXIMUM_SHUTDOWN_PEEKS
.
The number of times to peek on shutdown before giving up and shutting down.
TBA
Integer (default is 5000)
See org.apache.geode.internal.cache.GatewayImpl.#QUEUE_SIZE_THRESHOLD
.
The queue size threshold used to warn the user. If the queue reaches this size, log a warning.
TBA
Integer (default is 15000)
See org.apache.geode.internal.cache.GatewayImpl.#TOKEN_TIMEOUT
.
Timeout tokens in the unprocessedEvents map after this many milliseconds.
TBA
Integer (default is 500 * 1024)
See org.apache.geode.internal.cache.InitialImageOperation#CHUNK_SIZE_IN_BYTES
.
maximum number of bytes to put in a single message
TBA
Long (default is 100)
See org.apache.geode.distributed.internal.locks.GrantorRequestProcessor#ELDER_CHANGE_SLEEP
.
The number of milliseconds to sleep for elder change if current elder is departing (and already sent shutdown msg) but is still in the View.
TBA
Integer (default is 90)
See org.apache.geode.distributed.internal.membership.gms.GMSMembershipManager#isShunned
.
This is the length of time during which incoming messages from a departed peer are regarded as out-of-order messages and are hence ignored (shunned).
Units are in seconds.
Boolean (default is false)
Used internally by the locator. It sets it to true to tell other code that the member type should be LOCATOR. As of 7.0.
Boolean (default is false)
See org.apache.geode.distributed.internal.InternalLocator#INHIBIT_DM_BANNER
.
TBA
Integer (default is 20)
See org.apache.geode.internal.cache.ComplexDiskRegion#MAX_WAIT_FOR_SPACE
.
Units are in seconds.
TBA
Boolean (default is false)
See org.apache.geode.internal.StatArchiveReader(File[], ValueFilter[], boolean)
.
See org.apache.geode.internal.StatArchiveReader#dump(PrintWriter)
.
Boolean (default is false)
See org.apache.geode.internal.StatArchiveReader(File[], ValueFilter[], boolean)
.
TBA
Boolean (default is false)
Boolean
See org.apache.geode.internal.cache.StateFlushOperation#DEBUG
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.ReplyProcessor21#THROW_EXCEPTION_ON_TIMEOUT
.
TBA
String
Default is java.util.concurrent.NanoTimerProvider
.
See java.util.concurrent.Utils#providerProp.
This is the name of a class that implements the
java.util.concurrent.helpers.NanoTimer
interface.
TBA
String
See org.apache.geode.internal.OSProcess#bgexec(String[], File, File, boolean)
.
If this property exists and has non-zero length, additional information about
the executed command is printed to System.out
.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.PartitionedRegion#initPrInternals
.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.PartitionedRegionDataStore.PartitionedRegionDataStore(PartitionedRegion)
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.DistributionAdvisor#disabled
.
TBA
Boolean (default is false)
If true then non-replicate regions will turn a remote update they receive on an entry they do not have into a local create. By default these updates would have been ignored.
Boolean (default is false)
If true then transactions on persistent regions are allowed.
Integer -1
See org.apache.geode.internal.cache.GatewayEventRemoteDispatcher#ARTIFICIAL_DELAY
Introduce artificial delay (in ms) before batch sending to simulate a real WAN link
Boolean (default is false)
See org.apache.geode.internal.tcp.MsgStreamer#ASCII_STRINGS
.
See org.apache.geode.internal.HeapDataOutputStream#ASCII_STRINGS
.
Causes GemFire's implementation of writeUTF to only work for Strings that use the ASCII character set. So Strings that use the international characters will be serialized incorrectly. If you know your Strings only use ASCII setting this to true can improve your performance if you are using writeUTF frequently. Most Strings are serialized using DataSerializer.writeString which does not use writeUTF.
Boolean (default is false)
If set to true forces the ReflectionBasedAutoSerializer to not use the sun.misc.Unsafe code. Using Unsafe optimizes performance but reduces portablity. By default ReflectionBasedAutoSerializer will attempt to use Unsafe but silently not use it if it is not available.
Boolean (default is false)
If set to true then the ReflectionBasedAutoSerializer will throw an exception if it is not able to use the sun.misc.Unsafe code. Using Unsafe optimizes performance but reduces portablity. By default ReflectionBasedAutoSerializer will attempt to use Unsafe but silently not use it if it is not available.
Long (default is 2)
See org.apache.geode.internal.cache.PRHAFailureAndRecoveryPRovider#BUCKET_RECOVERY_DELAY
.
Mean amount of time, in seconds, to delay before starting to recover a bucket.
TBA
Long (default is 200)
See org.apache.geode.internal.cache.PRHAFailureAndRecoveryPRovider#BUCKET_RECOVERY_JITTER
.
Maximum additional amount of time, in milliseconds, to skew bucket creation, to stagger recovery and creation in a starting system.
TBA
Long (default is 1000 * 60)
See org.apache.geode.internal.cache.BucketAdvisor#GET_PRIMARY_TIMEOUT
.
Specifies the timeout to wait for a primary when calling {@link #getPrimary()}
Units are in milliseconds.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.GemFireCache#ASYNC_EVENT_LISTENERS
.
If true then cache event listeners will be invoked by a background thread. By default they are invoked by the same thread that is doing the cache operation.
Integer (default is 4096)
See org.apache.geode.internal.cache.GemFireCache#EVENT_QUEUE_LIMIT
.
TBA
Integer (default is 120)
See org.apache.geode.internal.cache.GemFireCache#DEFAULT_LOCK_LEASE
.
The default duration (in seconds) of a lease on a distributed lock
TBA
Integer (default is 60)
See org.apache.geode.internal.cache.GemFireCache#DEFAULT_LOCK_TIMEOUT
.
The default number of seconds to wait for a distributed lock
TBA
Integer (default is 300)
See org.apache.geode.internal.cache.GemFireCache#DEFAULT_SEARCH_TIMEOUT
.
The default amount of time to wait for a netSearch
to
complete
Units are in seconds.
TBA
Integer (default is Integer.MAX_VALUE - 10)
See org.apache.geode.internal.cache.GemFireCache#START_SERIAL_NUMBER
.
Specifies the starting serial number for the {@link #serialNumberSequencer
TBA
Integer (default is 1000)
See org.apache.geode.internal.cache.CacheDistributionAdvisor#ROLLOVER_THRESHOLD
.
Used to compare profile versioning numbers against {@link Integer#MAX_VALUE} and {@link Integer#MIN_VALUE} to determine if a rollover has occurred.
TBA
Integer (default is 230000)
See org.apache.geode.internal.cache.ha.HARegionQueueAttributes#BLOCKING_QUEUE_CAPACITY
.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.ExpirationScheduler#DEBUG
.
TBA
Long (default is 1024 * 1024 * 1024)
See org.apache.geode.internal.cache.DiskWriteAttributesImpl#DEFAULT_MAX_OPLOG_SIZE
.
default max in bytes
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.locks.DLockService.DLockService(String, DistributedSystem, boolean, boolean, boolean).
Integer (default is 10000)
See org.apache.geode.distributed.internal.locks.LockGrantorId#ROLLOVER_MARGIN
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_LOCK_REQUEST_LOOP
.
TBA
Integer (default is 20)
See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_LOCK_REQUEST_LOOP_COUNT
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_DISALLOW_NOT_HOLDER
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_ENFORCE_SAFE_EXIT
.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_NONGRANTOR_DESTROY_LOOP
.
TBA
Integer (default is 20)
See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_NONGRANTOR_DESTROY_LOOP_COUNT
.
TBA
Long (default is 2000)
See org.apache.geode.distributed.internal.locks.DLockService#NOT_GRANTOR_SLEEP
.
Units are in milliseconds.
TBA
Integer (default is Integer.MAX_VALUE - 10)
See org.apache.geode.distributed.internal.locks.DLockService#START_SERIAL_NUMBER
.
Specifies the starting serial number for the {@link #serialNumberSequencer}
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.LocalRegion#DO_EXPENSIVE_VALIDATIONS
.
TBA
Integer (default is Integer.MAX_VALUE - 10)
See org.apache.geode.distributed.internal.DistributionAdvisor#START_VERSION_NUMBER
.
Specifies the starting version number for the {@link #profileVersionSequencer}.
TBA
Integer (default is 0)
See org.apache.geode.internal.cache.ExpiryTask class init
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.LocalRegion#EXPIRY_UNITS_MS
.
Used by unit tests to set expiry to milliseconds instead of the default seconds. Used in ExpiryTask.
TBA
Integer (default is 15000)
See org.apache.geode.distributed.internal.PooledExecutorWithDMStats#PooledExecutorWithDMStats(BlockingQueue, int, PoolStatHelper, ThreadFactory)
.
Units are in milliseconds.
TBA
Boolean (default is false)
Tell admin API whether the member is a dedicated cache server
Float (default is 10.0)
See org.apache.geode.distributed.internal.LocatorLoadSnapshot
Sets the connection count threshold for rebalancing clients. When a client asks the locator whether it should switch to a less loaded server the locator will respond "no" if the connection-count gap between the highest-loaded server and the least-loaded server is within this threshold. If the threshold is reached the locator will aggressivley reassign clients until balance is re-established.
Integer (default for Sun/Oracle is 1 and for others 5)
See org.apache.geode.internal.cache.control.InternalResourceManager.#MEMORY_EVENT_TOLERANCE
Number of memory events that ResourceManager will tolerate before throwing a LME. Useful with JVM 1.7
Integer (default is 10000)
See org.apache.geode.internal.cache.ExpirationScheduler#MAX_PENDING_CANCELS
.
TBA
Integer (default is 1)
See org.apache.geode.internal.cache.partitioned.SizedBasedLoadProbe.#MIN_BUCKET_SIZE
Allows setting the minimum bucket size to be used during rebalance
Boolean (default is false)
If true then pr primary buckets will not be balanced when a new member is started.
Integer (default is 180)
See org.apache.geode.internal.cache.ha.HARegionQueue#REGION_ENTRY_EXPIRY_TIME
.
Constant used to set region entry expiry time using system property.
Units are in seconds.
TBA
Boolean (default is false)
See org.apache.geode.cache.client.internal.PoolImpl
Clear pdxType ids when client disconnects from servers
Boolean (default is false)
See org.apache.geode.admin.GemFireMonitorService#processGetValCommand
.
See org.apache.geode.admin.remote.RemoteCacheInfo.RemoteCacheInfo(GemFireCache)
.
See org.apache.geode.admin.remote.RootRegionResponse#create(DistributionManager, InternalDistributedMember)
.
See org.apache.geode.internal.cache.PartitionedRegionDataStore#createBucketRegion(int)
.
See org.apache.geode.internal.cache.PartitionedRegionHelper#getPRConfigRegion(Region, Cache)
.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.CachedDeserializableFactory#PREFER_DESERIALIZED
.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.CachedDeserializableFactory.#PREFER_DESERIALIZED
Enable storing the values in serialized form
Boolean (default is false)
See org.apache.geode.internal.cache.partitioned.PRSanityCheckMessage#schedule
.
TBA
Integer (default is 5000)
See org.apache.geode.internal.cache.partitioned.PRSanityCheckMessage#schedule
.
Units are in milliseconds.
TBA
Long (defaults to NanoTimer.getTime())
See org.apache.geode.internal.cache.PartitionedRegion#rand
.
Seed for the random number generator in this class.
TBA
Integer (defaults to 10 * 60 * 1000)
See org.apache.geode.cache.query.internal.DefaultQuery.#COMPILED_QUERY_CLEAR_TIME
Frequency of clean up compiled queries
See org.apache.geode.cache.query.internal.DefaultQuery.#QUERY_VERBOSE
Boolean (defaults to false)
Enable verbose logging in the query execution
Boolean (defaults to true)
See org.apache.geode.cache.query.internal.DefaultQueryService.#QUERY_HETEROGENEOUS_OBJECTS
Allow query on region with heterogeneous objects
Boolean (defaults to false)
See org.apache.geode.internal.cache.execute.InternalFunctionExecutionServiceImpl.#RANDOM_onMember
When set, onMember execution will be executed on a random member.
Integer (default is 1)
See org.apache.geode.internal.cache.partitioned.RegionAdvisor#VOLUNTERING_THREAD_COUNT
.
Number of threads allowed to concurrently volunteer for bucket primary.
TBA
Long (default is Long.MAX_VALUE)
See org.apache.geode.internal.cache.PartitionedRegion#VM_OWNERSHIP_WAIT_TIME
Time to wait for for acquiring distributed lock ownership
Time is specified in milliseconds.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.GatewayHubImpl#USE_ASYNCHRONOUS_DISTRIBUTION
.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.tier.sockets.ConnectionProxyImpl#disableShufflingOfEndpoints
.
A debug flag, which can be toggled by tests to disable/enable shuffling of the endpoints list
TBA
Boolean (default is false)
See ConnectionProxyImpl
,
ServerConnection
, and
ServerMonitor
.
TBA
Integer 10
See org.apache.geode.internal.cache.BridgeServerImpl.#FORCE_LOAD_UPDATE_FREQUENCY
How often to force a BridgeServer load message to be sent
Boolean default is false
See org.apache.geode.internal.cache.BucketRegion.#FORCE_LOCAL_LISTENERS_INVOCATION
Enable invocation of listeners in both primary and secondary buckets
Integer default is -1
See org.apache.geode.internal.cache.GemFireCacheImpl.#MAX_QUERY_EXECUTION_TIME
Limit the max query execution time (ms)
Integer default is 0
See org.apache.geode.cache.client.internal.ConnectioImpl.#CLIENT_FUNCTION_TIMEOUT
Timeout to set for client function execution
String (default is unset, to use System.out)
See org.apache.geode.admin.GemFireClientAdminTool#logFileName
.
This is a file name.
TBA
String
See org.apache.geode.internal.SocketCreator
Non-standard Socket creator
Boolean true
See org.apache.geode.cache.query.internal.CqService.#EXECUTE_QUERY_DURING_INIT
When set to false, avoid query execution during CQ when initial results are not required
Boolean (default is false)
See org.apache.geode.internal.SharedLibrary#getName
.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.entries.AbstractRegionEntry.#DISABLE_ACCESS_TIME_UPDATE_ON_PUT
Disable access time updates on put event
Boolean (default is false)
See org.apache.geode.internal.cache.EntryEventImpl#EVENT_OLD_VALUE
.
Discussing EVENT_OLD_VALUE = !Boolean.getBoolean():
If true (the default) then preserve old values in events. If false then mark non-null values as being NOT_AVAILABLE.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.PartitionedRegion.#DISABLE_SECONDARY_BUCKET_ACK
Enable no-ack replication in bucket regions
Boolean (default is false)
See org.apache.geode.internal.cache.DistributedCacheOperation#UDP_DISABLE_DIRECT_ACK
.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.tier.sockets.CacheClientProxy#LOG_DROPPED_MSGS
.
Discussing LOG_DROPPED_MSGS = !Boolean.getBoolean():
Defaults to true; meaning do some logging of dropped client notification messages. Set the system property to true to cause dropped messages to NOT be logged.
TBA
Boolean (default is false)
If true then the shutdown hooks of the DistributedSystem, Locator, and Agent are not run on shutdown. This was added for bug 38407.
Boolean (default is false)
Used by unit tests to make sure the GemFire mcast-port has been configured to a non-default value.
Boolean (default is true)
See org.apache.geode.internal.cache.SimpleDiskRegion
.
Whether to get the values from disk to memory on recovery
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.LocalRegion.#EXPIRATIONS_CAUSE_CONFLICTS
Allow expirations to be done by multiple threads, avoiding the pendingExpires list (set in conjunction with gemfire.EXPIRY_THREADS)
Boolean (default is false)
This property causes the per thread stats to also measure cpu time. This property is ignored unless "gemfire.enableThreadStats" is also set to true. See java.lang.management.ThreadMXBean.setThreadCpuTimeEnabled(boolean) for more information.
Boolean (default is false)
This property causes the per thread stats to also measure contention. This property is ignored unless "gemfire.enableThreadStats" is also set to true. See java.lang.management.ThreadMXBean.setThreadContentionMonitoringEnabled(boolean) for more information.
Boolean (default is false)
This property causes the per thread stats to be collected. See java.lang.management.ThreadMXBean for more information.
Boolean (default is false)
See org.apache.geode.internal.cache.GatewayHubImpl#ALLOW_CONSERVE_SOCKETS
.
A boolean that defines whether the value of the conserve-sockets property in the gemfire.properties file is preserved. By default, the value in gemfire.properties is overridden so that queue ordering is preserved. If ALLOW_CONSERVE_SOCKETS=true, then the conserve-sockets property is used and queue ordering may not be preserved. This property can be set using the System property called 'gemfire.gateway-conserve-sockets-allowed'.
TBA
Boolean (default is false)
See org.apache.geode.internal.cache.SingleWriteSingleReadRegionQueue#NO_ACK
.
Whether the Gateway
queue should be no-ack instead of ack.
TBA
Boolean (default is false)
If true causes the GatewayReceiver will apply batches it has already received.
Boolean (default is false)
See org.apache.geode.internal.cache.tier.sockets.ServerConnection#APPLY_RETRIES
.
TBA
Integer (default is 16)
See org.apache.geode.internal.cache.InitialImageOperation.#CHUNK_PERMITS
Allowed number of in-flight initial image chunks. This property controls how many requests for GII chunks can be handled simultaneously.
Integer (default is 5)
See org.apache.geode.internal.cache.InitialImageOperation.#MAX_PARALLEL_GIIS
Allowed number of GIIs in parallel. This property controls how many regions can do GII simultaneously. Each replicated region and partitioned region bucket counts against this number.
Boolean (default is false)
See org.apache.geode.internal.Assert#debug
.
Causes VM to hang on assertion failure (to allow a debugger to be attached) instead of exiting the process.
Boolean (default is false)
On OSes that support it bind to the mcast_addr to prevent traffic on different addresses, but on the same port. Setting to true can avoid cross address chatter.
Boolean (default is false)
Causes the code used by gfsh to launch a server or locator to install signal handlers using sun.misc.Signal.
Boolean (default is false)
See org.apache.geode.internal.PureJavaMode#debug
.
TBA
String
See org.apache.geode.internal.gui.RemoteCommandManager#getLocatorStart
.
See org.apache.geode.internal.gui.StartStopManager#startLocalLocator
.
A JVM property, esp. "-Xms150m".
TBA
See org.apache.geode.internal.gui.RemoteCommandManager#getLocatorStart
.
See org.apache.geode.internal.gui.StartStopManager#startLocalLocator
.
A JVM property, esp. "-Xmx400m"
TBAString
See the constructor for org.apache.geode.distributed.internal.InternalLocator
.
If this property is not found in gemfire.properties, the system property of the same name is used.
Integer (default is -1)
See org.apache.geode.internal.cache.lru.NewLRUClockHand#maxEntries
.
This is the maximum number of "good enough" entries to pass over for eviction before settling on the next acceptable entry. This prevents excessive cache processing to find a candidate for eviction.
Boolean (default is false)
See org.apache.geode.internal.cache.partitioned.GetMessage#ORDER_PR_GETS
.
TBA
Integer (default is 60 * 60 * 1000)
See org.apache.geode.internal.cache.PartitionedRegion#retryTimeout
The maximum milliseconds for retrying operations
TBA
Integer 1+ (default is 2)
See org.apache.geode.internal.cache.PRQueryProcessor#executeQuery
The number of concurrent threads to use within a single VM to execute queries on a Partitioned Region. If set to 1 (or less) then queries are run sequentially with a single thread.
TBA
Boolean (default is false)
See org.apache.geode.internal.PureJavaMode class init
.
Force use of "pure" Java mode (native libraries will not be loaded)
Boolean (default is false)
See org.apache.geode.cache.client.internal.PoolImpl.#SPECIAL_DURABLE
Makes multiple durable subscriptions from same client unique. on java client ensures only a single server proxy is created but will limit the client to a single active client pool at a time
Boolean (default is false)
See org.apache.geode.distributed.internal.InternalDistributedSystem#statsDisabled
.
TBA
Long (default is 5000)
See org.apache.geode.admin.GemFireClientAdminTool#_statusPollingDelay
.
Units are in milliseconds.
TBA
Boolean
See org.apache.geode.internal.cache.Oplog#SYNC_WRITES
.
This system property instructs that writes be synchronously written to disk and not to file system. (Use rwd instead of rw - RandomAccessFile property)
TBA
Integer
This property limits the number of threads that the locator will use for processing messages.
TBA
Integer default is 1280 but is limited by the OS somaxconn setting
This property establishes a Locator's TCP/IP "accept" backlog for locator communications.
TBA
Boolean (default is false)
See org.apache.geode.distributed.internal.DistributionConfig#VALIDATE
.
TBA
Integer (default is 8 * 1024 * 1024)
See org.apache.geode.distributed.internal.DistributionConfig#VALIDATE_CEILING
.
TBA
String
See org.apache.geode.distributed.DistributedSystem#PROPERTY_FILE
.
ThePROPERTY_FILE
is the name of the property file that the connect method will check for when it looks for a property file. The file will be searched for, in order, in the following directories:Only the first file found will be used.
- the current directory
- the home directory
- the class path
The default value of PROPERTY_FILE is
@since GemFire 5.0"gemfire.properties"
. However if the "gemfirePropertyFile" system property is set then its value is the value of PROPERTY_FILE. If this value is a relative file system path then the above search is done. If it is an absolute file system path then that file must exist; no search for it is done.
TBA
Integer (default is 20)
See org.apache.geode.internal.cache.PartitionedRegionDataStore.BucketRecoverer#grabBuckets
.
TBA
Boolean
See org.apache.geode.admin.jmx.internal.AgentImpl#checkDebug
.
Enables mx4j tracing if Agent debugging is enabled.
TBA
String
See org.apache.geode.admin.jmx.internal.AgentConfigImpl#retrievePropertyFile
.
ThepropertyFile
is the name of the property file that will be loaded on startup of the Agent.The file will be searched for, in order, in the following directories:
Only the first file found will be used.
- the current directory
- the home directory
- the class path
The default value of propertyFile is
"agent.properties"
. However if the "gfAgentPropertyFile" system property is set then its value is the value of propertyFile. If this value is a relative file system path then the above search is done. If its an absolute file system path then that file must exist; no search for it is done.
TBA
String
See org.apache.geode.internal.gui.Service#initProps()
.
This is name of a Properties
file read at startup.
TBA
See org.apache.geode.internal.gui.Service#saveProps
.
This is the name of a Properties
file to which some properties
are saved a close.
TBA
Boolean (default is false)
See org.apache.geode.internal.gui.NavigationPane#NavigationPane()
.
See org.apache.geode.internal.gui.Service#Service()
.
TBA
Boolean
See org.apache.geode.internal.jta.GlobalTransaction#VERBOSE
.
See org.apache.geode.internal.jta.TransactionManagerImpl#VERBOSE
.
TBA
Integer (default is 600)
See org.apache.geode.internal.jta.TransactionManagerImpl#DEFAULT_TRANSACTION_TIMEOUT
.
Units are in seconds.
TBA Is this a standard JTA property?
Boolean (default is false)
See org.apache.geode.internal.LogFileParser#TRIM_TIMESTAMPS
.
TBA
String (default is org.apache.commons.logging.impl.SimpleLog)
See org.apache.geode.admin.jmx.internal.AgentImpl class init
.
This is the name of a class.
This property is also used by commons-logging.jar (and discussed below). It is called out here because of its explicit use in the JMX Agent.
Boolean (default is false)
See org.apache.geode.internal.GemFireStatSampler#osStatsDisabled
.
TBA
Boolean (default is false)
See org.apache.geode.internal.tcp.TCPConduit#DEBUG
.
TBA
Boolean (default is false)
See org.apache.geode.internal.tcp.TCPConduit#QUIET
.
TBA
Integer (default is 1280 but limited by OS somaxconn setting)
See org.apache.geode.internal.tcp.TCPConduit#BACKLOG
.
backlog is the TCP/IP "accept" backlog configuration parameter for cluster communications
TBA
Integer (default is 1024 * 1024)
See org.apache.geode.internal.tcp.Connection#BATCH_BUFFER_SIZE
.
TBA
Integer in Connection.
See org.apache.geode.internal.tcp.Connection#BATCH_FLUSH_MS
.
(Default is 50)
Max number of milliseconds until queued messages are sent. Messages are sent when max_bundle_size or max_bundle_timeout has been exceeded (whichever occurs faster)
TBA
Boolean (default is false)
See org.apache.geode.internal.tcp.Connection#BATCH_SENDS
.
TBA
String (one of "config", "fine", "finer", or "finest")
See org.apache.geode.internal.tcp.TCPConduit#getLogger
.
Used only if this class needs to create a logger.
TBA
Boolean (defaults to false)
See org.apache.geode.internal.tcp.Connection#SOCKET_WRITE_DISABLED
.
use to test message prep overhead (no socket write). WARNING: turning this on completely disables distribution of batched sends
TBA
Integer (default is 3000)
See org.apache.geode.distributed.internal.membership.gms.GMSMembershipManager#destroyMember
.
TBA Workaround for bug 34010: small pause inserted before closing reader threads for a departed member.
Integer (default is 59000)
See org.apache.geode.internal.tcp.Connection#HANDSHAKE_TIMEOUT_MS
.
TBA
Integer (default is 10)
See org.apache.geode.internal.tcp
.
Long (default is 60000 for a server and 24000 for a locator)
See org.apache.geode.distributed.internal.membership.adapter.ServiceConfig
.
Establishes the timeout for waiting for a join response when connecting to the cluster
Units are in milliseconds.
TBA
Integer (default is 5000)
See org.apache.geode.internal.tcp.Connection#Connection(ConnectionTable, Socket)
.
Sets the SO_LINGER
time on direct channel TCP sockets.
Units are in milliseconds.
Integer (default is 60000)
See org.apache.geode.internal.tcp.TCPConduit#LISTENER_CLOSE_TIMEOUT
.
max amount of time (ms) to wait for listener threads to stop
TBA
Integer (default is p2p.defaultConcurrencyLevel)
See org.apache.geode.distributed.internal.direct.DirectChannel#MAX_GROUP_SENDERS
.
The maximum number of concurrent senders sending a message to a group of recipients.
TBA
Boolean (default is false)
See org.apache.geode.internal.net.BufferPool#useDirectBuffers
.
use java "heap" ByteBuffers instead of direct ByteBuffers for NIO operations. Recommended if TLSv1 is being used or if you find you are running out of direct-memory and do not want to increase the amount of direct-memory available to the JVM. Use of heap buffers can reduce performance in some cases.
TBA
Boolean (default is false)
See org.apache.geode.internal.tcp.TCPConduit#useNIO
.
If set, don't use java.nio.
Integer (default is 32768)
See org.apache.geode.internal.tcp.Connection#INITIAL_CAPACITY
.
TBA
Integer (default is 32768)
See TCPConduit.
Any value smaller than 1024 will be set to 1024. If the gemfire property socket-buffer-size is set to a value other than 32768 then this system property will be ignored. Otherwise this system property sets the p2p socket-buffer-size.
Units are are bytes.
Boolean (default is false)
See org.apache.geode.internal.tcp.TCPConduit#startAcceptor(int, int, InetAddress).
TBA
Boolean (default is false)
See org.apache.geode.cache.query.internal.index.IndexUtils#indexesEnabled.
TBA
Integer (default is 10, unless the Integer.parseInt throws a NumberFormatException in which case, the value is 5)
See org.apache.geode.internal.admin.remote.RemoteCall#getPopupTime.
Units are in seconds.
TBA
Integer (default is 1800)
See org.apache.geode.internal.admin.remote.AdminWaiters#getWaitTimeout.
Units are in seconds.
TBA
Boolean (default is false)
Removed in Geode 1.0 with removal of deprecated Bridge classes.
TBALong (default is 5000)
See org.apache.geode.internal.cache.tier.sockets.CacheClientProxy.MessageDispatcher#slowStartTimeForTesting.
Units are in milliseconds.
TBA
String
See org.apache.geode.internal.SimpleStatSampler#archiveFileName.
This is a filename.
TBA
Boolean (default is false)
See org.apache.geode.internal.LocalStatisticsFactory#statsDisabled.
TBA
Long (default is 1024 * 1024)
See org.apache.geode.internal.SimpleStatSampler#archiveDiskSpaceLimit.
TBA
Long (default is 0)
See org.apache.geode.internal.SimpleStatSampler#archiveFileSizeLimit.
Units are in megabytes
TBA
String (See LogWriterImpl.levelNameToCode)
See org.apache.geode.internal.LocalStatisticsFactory#logLevel.
TBA
String
See org.apache.geode.internal.LocalStatisticsFactory#name.
TBA
Integer (default is 1000)
See org.apache.geode.internal.SimpleStatSampler#sampleRate.
Units are in milliseconds.
TBA
Integer
See org.apache.geode.internal.gui.Service#Service().
A multicast port for a distributed system that will automatically be created by the console. Its value can be set via a system property. It is used only for testing.
TBA
Integer (default is the tcp-port property in the distribution config)
See org.apache.geode.distributed.internal.direct.DirectChannel#DirectChannel(MembershipManager, DistributedMembershipListener, DistributionConfig, LogWriter, Properties).
TBA
String
Default is org.apache.commons.logging.impl.Log4JLogger (if available), else org.apache.commons.logging.impl.Jdk14Logger, else org.apache.commons.logging.impl.SimpleLog.
See org.apache.commons.logging.impl.LogFactoryImpl#LOG_PROPERTY
The name of the system property identifying our {@link Log} implementation class.
String (default is "yyyy/MM/dd HH:mm:ss:SSS zzz")
String format derived from SimpleDateFormat.
See org.apache.commons.logging.impl.SimpleLog class init
.
"Used to format times"
Boolean (default is false)
See org.apache.commons.logging.impl.SimpleLog class init
.
Include the current time in the log message
Boolean (default is false)
See org.apache.commons.logging.impl.SimpleLog class init
.
"Include the instance name in the log message?"
String (default is true)
See org.apache.commons.logging.impl.SimpleLog class init
.
Include the short name ( last component ) of the logger in the log message. Default to true - otherwise we'll be lost in a flood of messages without knowing who sends them.
String
X509Certificate implementation. See the JSSE documentation.
String
HTTPS protocol implementation. See the JSSE documentation.
String
Geniric dynamic debug tracing support. See the JSSE documentation.
String
JSSE-specific dynamic debug tracing support. See the JSSE documentation.
String
default keystore. See the JSSE documentation.
String
default keystore type. See the JSSE documentation.
String
default keystore password. See the JSSE documentation.
String
If the system property javax.net.ssl.trustStore is defined, then the TrustManagerFactory attempts to find a file using the filename specified by that system property, and uses that file for the KeyStore. If that file does not exist, then a default TrustManager using an empty keystore is created.
String
default truststore password. See the JSSE documentation.