Introduction

Please edit this file by hand in order to facilitate merges!

Please keep entries in this file in alphabetical order in order to facilitate merging!

Java Methods Swept

These are the methods that I have found that reference the system properties table. If you can think of others I have missed, add them (alphabetically) to this list, perform the sweep using Eclipse and add your results.

Miscellaneous

DistributionConfigImpl constructor prepends 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:

Properties, in Alphabetical Order

AdminDistributedSystemImpl.TIMEOUT_MS
Public: false

Integer (default is 60000)

See org.apache.geode.admin.internal.AdminDistributedSystemImpl#TIMEOUT_MS.

TBA

AvailablePort.fastRandom
Public: false

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.

AvailablePort.timeout
Public: false

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.

Bridge.VERBOSE
Public: false

See org.apache.geode.internal.cache.BridgeServerImpl.#VERBOSE.

Enable verbose logging in the BridgeServer

BridgeServer.HANDSHAKE_POOL_SIZE
Public: true

Integer (default is 4)

See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#HANDSHAKE_POOL_SIZE.

TBA

BridgeServer.MAXIMUM_CHUNK_SIZE
Public: true

Integer (default is 100)

See org.apache.geode.internal.cache.tier.sockets.ServerConnection#maximumChunkSize.

TBA

BridgeServer.MAX_INCOMING_DATA
Public: true

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

BridgeServer.MAX_INCOMING_MSGS
Public: true

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

BridgeServer.SELECTOR
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#DEPRECATED_SELECTOR.

TBA

BridgeServer.SELECTOR_POOL_SIZE
Public: false

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

BridgeServer.SOCKET_BUFFER_SIZE
Public: true

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

BridgeServer.acceptTimeout
Public: false

Integer (default is 2900)

See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#acceptTimeout.

Units are in milliseconds.

  Test value for accept timeout

TBA

BridgeServer.backlog
Public: false

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.

BridgeServer.handShakeTimeout
Public: false

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

DataSerializer.DEBUG
Public: false

Boolean (default is false)

See org.apache.geode.DataSerializer#DEBUG

TBA

DataSerializer.DUMP_SERIALIZED
Public: false

Boolean (default is false)

See org.apache.geode.DataSerializer#DUMP_SERIALIZED

TBA

DistributedLockService.VERBOSE
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.locks.DLockLogWriter#VERBOSE.

Enables logging for this class.

DistributionManager.DISCONNECT_WAIT
Public: false

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

DistributionManager.INCOMING_QUEUE_LIMIT
Public: false

Integer (default is 80000)

See org.apache.geode.distributed.internal.DistributionManager#INCOMING_QUEUE_LIMIT.

TBA

DistributionManager.INCOMING_QUEUE_THROTTLE
Public: false

Integer (default is INCOMING_QUEUE_LIMIT * .75)

See org.apache.geode.distributed.internal.DistributionManager#INCOMING_QUEUE_THROTTLE.

TBA

DistributionManager.MAX_FE_THREADS
Public: false

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.

DistributionManager.MAX_PR_THREADS
Public: false

Integer (default is 200 or 32 * number of processors, whichever is larger)

See org.apache.geode.distributed.internal.DistributionManager#MAX_PR_THREADS.

TBA

DistributionManager.MAX_SERIAL_QUEUE_THREAD
Public: false

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

DistributionManager.MAX_THREADS
Public: false

Integer (default is 1000)

See org.apache.geode.distributed.internal.DistributionManager#MAX_THREADS.

TBA

DistributionManager.MAX_WAITING_THREADS
Public: false

Integer (default is Integer.MAX_VALUE)

See org.apache.geode.distributed.internal.DistributionManager#MAX_WAITING_THREADS.

TBA

DistributionManager.OptimizedUpdateByteLimit
Public: false

Integer (default is 2000)

See org.apache.geode.internal.cache.SearchLoadAndWriteProcessor#SMALL_BLOB_SIZE.

TBA

DistributionManager.PUSHER_QUEUE_SIZE
Public: false

Integer (default is 4096)

See org.apache.geode.distributed.internal.DistributionManager#PUSHER_QUEUE_SIZE.

TBA

DistributionManager.PUSHER_THREADS
Public: false

Integer (default is 50)

See org.apache.geode.distributed.internal.DistributionManager#PUSHER_THREADS.

TBA

DistributionManager.SERIAL_QUEUE_BYTE_LIMIT
Public: false

Integer (default is 40 * 1024 * 1024)

See org.apache.geode.distributed.internal.DistributionManager#SERIAL_QUEUE_BYTE_LIMIT.

TBA

DistributionManager.SERIAL_QUEUE_SIZE_LIMIT
Public: false

Integer (default is 20000)

See org.apache.geode.distributed.internal.DistributionManager#SERIAL_QUEUE_SIZE_LIMIT.

TBA

DistributionManager.SERIAL_QUEUE_SIZE_THROTTLE
Public: false

Integer (default is SERIAL_QUEUE_SIZE_LIMIT * THROTTLE_PERCENT)

See org.apache.geode.distributed.internal.DistributionManager#SERIAL_QUEUE_THROTTLE.

TBA

DistributionManager.SERIAL_QUEUE_THROTTLE_PERCENT
Public: false

Integer (default is 75)

See org.apache.geode.distributed.internal.DistributionManager#THROTTLE_PERCENT.

TBA

DistributionManager.STARTUP_TIMEOUT
Public: false

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

DistributionManager.TIMEOUT
Public: false

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

DistributionManager.TOTAL_SERIAL_QUEUE_BYTE_LIMIT
Public: false

Integer (default is 80 * 1024 * 1024)

See org.apache.geode.distributed.internal.DistributionManager#TOTAL_SERIAL_QUEUE_BYTE_LIMIT.

TBA

DistributionManager.TOTAL_SERIAL_QUEUE_THROTTLE
Public: false

Integer (default is SERIAL_QUEUE_BYTE_LIMIT * THROTTLE_PERCENT)

See org.apache.geode.distributed.internal.DistributionManager#TOTAL_SERIAL_QUEUE_THROTTLE.

TBA

DistributionManager.VERBOSE
Public: true

Boolean (default is false)

See org.apache.geode.distributed.internal.DistributionManager#VERBOSE.

Enables certain additional (fine-level?) logging.

DistributionManager.VERBOSE_VIEWS
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.membership.gms.GMSMembershipManager#VERBOSE_VIEWS.

Enables additional info-level logging (see #addShunnedMember and #addSurpriseMember).

DistributionManager.enqueueOrderedMessages
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.DistributionManager#INLINE_PROCESS.

TBA

DistributionManager.requireAllStartupResponses
Public: false

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.

DistributionManager.singleSerialExecutor
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.DistributionManager#MULTI_SERIAL_EXECUTORS.

TBA

DistributionManager.syncEvents
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.DistributionManager#SYNC_EVENTS.

TBA

DynamicRegionFactory.disablePersistence
Public: false

Boolean (default is false)

See org.apache.geode.cache.DynamicRegionFactory#DISABLE_PERSIST_BACKUP.

TBA

DynamicRegionFactory.disableRegisterInterest
Public: false

Boolean (default is false)

See org.apache.geode.cache.DynamicRegionFactory#DISABLE_REGISTER_INTEREST.

TBA

DynamicRegionFactory.msDelay
Public: false

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

Gateway.EVENT_TIMEOUT
Public: false

Integer (default is 5 * 60 * 1000)

See org.apache.geode.internal.cache.GatewayImpl.EventWrapper#EVENT_TIMEOUT.

Units are in milliseconds.

TBA

Gateway.MAXIMUM_SHUTDOWN_PEEKS
Public: false

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

Gateway.QUEUE_SIZE_THRESHOLD
Public: false

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

Gateway.TOKEN_TIMEOUT
Public: false

Integer (default is 15000)

See org.apache.geode.internal.cache.GatewayImpl.#TOKEN_TIMEOUT.

  Timeout tokens in the unprocessedEvents map after this many milliseconds.

TBA

GetInitialImage.chunkSize
Public: true

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

GrantorRequestProcessor.ELDER_CHANGE_SLEEP
Public: false

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

gemfire.shunned-member-timeout
Public: false

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.

Locator.forceLocatorDMType
Public: false

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.

Locator.inhibitDMBanner
Public: true

Boolean (default is false)

See org.apache.geode.distributed.internal.InternalLocator#INHIBIT_DM_BANNER.

TBA

MAX_WAIT_FOR_SPACE
Public: false

Integer (default is 20)

See org.apache.geode.internal.cache.ComplexDiskRegion#MAX_WAIT_FOR_SPACE.

Units are in seconds.

TBA

StatArchiveReader.dump
Public: false

Boolean (default is false)

See org.apache.geode.internal.StatArchiveReader(File[], ValueFilter[], boolean).

See org.apache.geode.internal.StatArchiveReader#dump(PrintWriter).

StatArchiveReader.dumpall
Public: false

Boolean (default is false)

See org.apache.geode.internal.StatArchiveReader(File[], ValueFilter[], boolean).

TBA

StateFlushOperation.DEBUG
Public: false

Boolean (default is false)

Boolean

See org.apache.geode.internal.cache.StateFlushOperation#DEBUG.

TBA

ack-threshold-exception
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.ReplyProcessor21#THROW_EXCEPTION_ON_TIMEOUT.

TBA

java.util.concurrent.NanoTimerProvider
Public: false

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

org.apache.geode.logging.internal.OSProcess.trace
Public: false

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

org.apache.geode.internal.cache.PartitionedRegion-logging
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.PartitionedRegion#initPrInternals.

TBA

org.apache.geode.internal.cache.PartitionedRegionDataStore-logging (constructor)
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.PartitionedRegionDataStore.PartitionedRegionDataStore(PartitionedRegion).

TBA

disable-intelligent-msg
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.DistributionAdvisor#disabled.

TBA

GemFire.ALWAYS_REPLICATE_UPDATES
Public: false

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.

gemfire.ALLOW_PERSISTENT_TRANSACTIONS
Public: true

Boolean (default is false)

If true then transactions on persistent regions are allowed.

gemfire.artificialGatewayDelay
Public: false

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

gemfire.ASCII_STRINGS
Public: false

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.

gemfire.AutoSerializer.SAFE
Public: false

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.

gemfire.AutoSerializer.UNSAFE
Public: false

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.

gemfire.BUCKET_RECOVERY_DELAY
Public: false

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

gemfire.BUCKET_RECOVERY_JITTER
Public: false

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

gemfire.BucketAdvisor.getPrimaryTimeout
Public: false

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

gemfire.Cache.ASYNC_EVENT_LISTENERS
Public: true

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.

gemfire.Cache.EVENT_QUEUE_LIMIT
Public: false

Integer (default is 4096)

See org.apache.geode.internal.cache.GemFireCache#EVENT_QUEUE_LIMIT.

TBA

gemfire.Cache.defaultLockLease
Public: false

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

gemfire.Cache.defaultLockTimeout
Public: false

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

gemfire.Cache.defaultSearchTimeout
Public: false

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

gemfire.Cache.startSerialNumber
Public: false

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

gemfire.CacheDistributionAdvisor.rolloverThreshold
Public: false

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

gemfire.Capacity
Public: false

Integer (default is 230000)

See org.apache.geode.internal.cache.ha.HARegionQueueAttributes#BLOCKING_QUEUE_CAPACITY.

TBA

gemfire.DEBUG_EXPIRATION
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.ExpirationScheduler#DEBUG.

TBA

gemfire.DEFAULT_MAX_OPLOG_SIZE
Public: false

Long (default is 1024 * 1024 * 1024)

See org.apache.geode.internal.cache.DiskWriteAttributesImpl#DEFAULT_MAX_OPLOG_SIZE.

  default max in bytes

TBA

gemfire.DLockService.automateFreeResources
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.locks.DLockService.DLockService(String, DistributedSystem, boolean, boolean, boolean).

gemfire.DLockService.LockGrantorId.rolloverMargin
Public: false

Integer (default is 10000)

See org.apache.geode.distributed.internal.locks.LockGrantorId#ROLLOVER_MARGIN.

TBA

gemfire.DLockService.debug.disallowLockRequestLoop
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_LOCK_REQUEST_LOOP.

TBA

gemfire.DLockService.debug.disallowLockRequestLoopCount
Public: false

Integer (default is 20)

See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_LOCK_REQUEST_LOOP_COUNT.

TBA

gemfire.DLockService.debug.disallowNotHolder
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_DISALLOW_NOT_HOLDER.

TBA

gemfire.DLockService.debug.enforceSafeExit
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_ENFORCE_SAFE_EXIT.

TBA

gemfire.DLockService.debug.nonGrantorDestroyLoop
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_NONGRANTOR_DESTROY_LOOP.

TBA

gemfire.DLockService.debug.nonGrantorDestroyLoopCount
Public: false

Integer (default is 20)

See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_NONGRANTOR_DESTROY_LOOP_COUNT.

TBA

gemfire.DLockService.notGrantorSleep
Public: false

Long (default is 2000)

See org.apache.geode.distributed.internal.locks.DLockService#NOT_GRANTOR_SLEEP.

Units are in milliseconds.

TBA

gemfire.DistributedLockService.startSerialNumber
Public: false

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

gemfire.DO_EXPENSIVE_VALIDATIONS
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.LocalRegion#DO_EXPENSIVE_VALIDATIONS.

TBA

gemfire.DistributionAdvisor.startVersionNumber
Public: false

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

gemfire.EXPIRY_THREADS
Public: false

Integer (default is 0)

See org.apache.geode.internal.cache.ExpiryTask class init

TBA

gemfire.EXPIRY_UNITS_MS
Public: false

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

gemfire.IDLE_THREAD_TIMEOUT
Public: false

Integer (default is 15000)

See org.apache.geode.distributed.internal.PooledExecutorWithDMStats#PooledExecutorWithDMStats(BlockingQueue, int, PoolStatHelper, ThreadFactory).

Units are in milliseconds.

TBA

gemfire.isDedicatedServer
Public: false

Boolean (default is false)

Tell admin API whether the member is a dedicated cache server

gemfire.locator-load-imbalance-threshold
Public: true

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.

gemfire.memoryEventTolerance
Public: false

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

gemfire.MAX_PENDING_CANCELS
Public: false

Integer (default is 10000)

See org.apache.geode.internal.cache.ExpirationScheduler#MAX_PENDING_CANCELS.

TBA

gemfire.MIN_BUCKET_SIZE
Public: false

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

gemfire.DISABLE_MOVE_PRIMARIES_ON_STARTUP
Public: false

Boolean (default is false)

If true then pr primary buckets will not be balanced when a new member is started.

gemfire.MessageTimeToLive
Public: false

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

gemfire.ON_DISCONNECT_CLEAR_PDXTYPEIDS
Public: false

Boolean (default is false)

See org.apache.geode.cache.client.internal.PoolImpl

Clear pdxType ids when client disconnects from servers

gemfire.PRDebug
Public: false

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

gemfire.PREFER_DESERIALIZED
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.CachedDeserializableFactory#PREFER_DESERIALIZED.

TBA

gemfire.PREFER_SERIALIZED
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.CachedDeserializableFactory.#PREFER_DESERIALIZED

Enable storing the values in serialized form

gemfire.PRSanityCheckDisabled
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.partitioned.PRSanityCheckMessage#schedule.

TBA

gemfire.PRSanityCheckInterval
Public: false

Integer (default is 5000)

See org.apache.geode.internal.cache.partitioned.PRSanityCheckMessage#schedule.

Units are in milliseconds.

TBA

gemfire.PartitionedRegionRandomSeed
Public: false

Long (defaults to NanoTimer.getTime())

See org.apache.geode.internal.cache.PartitionedRegion#rand.

Seed for the random number generator in this class.

TBA

gemfire.Query.COMPILED_QUERY_CLEAR_TIME
Public: false

Integer (defaults to 10 * 60 * 1000)

See org.apache.geode.cache.query.internal.DefaultQuery.#COMPILED_QUERY_CLEAR_TIME

Frequency of clean up compiled queries

gemfire.Query.VERBOSE
Public: false

See org.apache.geode.cache.query.internal.DefaultQuery.#QUERY_VERBOSEBoolean (defaults to false)

Enable verbose logging in the query execution

gemfire.QueryService.QueryHeterogeneousObjects
Public: false

Boolean (defaults to true)

See org.apache.geode.cache.query.internal.DefaultQueryService.#QUERY_HETEROGENEOUS_OBJECTS

Allow query on region with heterogeneous objects

gemfire.randomizeOnMember
Public: false

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.

gemfire.RegionAdvisor.volunteeringThreadCount
Public: false

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

gemfire.VM_OWNERSHIP_WAIT_TIME
Public: false

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

gemfire.asynchronous-gateway-distribution-enabled
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.GatewayHubImpl#USE_ASYNCHRONOUS_DISTRIBUTION.

TBA

gemfire.bridge.disableShufflingOfEndpoints
Public: false

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

gemfire.bridge.suppressIOExceptionLogging
Public: false

Boolean (default is false)

See ConnectionProxyImpl, ServerConnection, and ServerMonitor.

TBA

gemfire.BridgeServer.FORCE_LOAD_UPDATE_FREQUENCY
Public: false

Integer 10

See org.apache.geode.internal.cache.BridgeServerImpl.#FORCE_LOAD_UPDATE_FREQUENCY

How often to force a BridgeServer load message to be sent

gemfire.BucketRegion.alwaysFireLocalListeners
Public: false

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

gemfire.Cache.MAX_QUERY_EXECUTION_TIME
Public: true

Integer default is -1

See org.apache.geode.internal.cache.GemFireCacheImpl.#MAX_QUERY_EXECUTION_TIME

Limit the max query execution time (ms)

gemfire.CLIENT_FUNCTION_TIMEOUT
Public: false

Integer default is 0

See org.apache.geode.cache.client.internal.ConnectioImpl.#CLIENT_FUNCTION_TIMEOUT

Timeout to set for client function execution

gemfire.clientMonitorLogFile
Public: false

String (default is unset, to use System.out)

See org.apache.geode.admin.GemFireClientAdminTool#logFileName.

This is a file name.

TBA

gemfire.clientSocketFactory
Public: false

String

See org.apache.geode.internal.SocketCreator

Non-standard Socket creator

gemfire.cq.EXECUTE_QUERY_DURING_INIT
Public: true

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

gemfire.debug
Public: false

Boolean (default is false)

See org.apache.geode.internal.SharedLibrary#getName.

TBA

gemfire.disableAccessTimeUpdateOnPut
Public: true

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

gemfire.disable-event-old-value
Public: false

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

gemfire.disablePartitionedRegionBucketAck
Public: true

Boolean (default is false)

See org.apache.geode.internal.cache.PartitionedRegion.#DISABLE_SECONDARY_BUCKET_ACK

Enable no-ack replication in bucket regions

gemfire.disable-udp-direct-ack
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.DistributedCacheOperation#UDP_DISABLE_DIRECT_ACK.

TBA

gemfire.disableNotificationWarnings
Public: false

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

gemfire.disableShutdownHook
Public: true

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.

gemfire.disallowMcastDefaults
Public: false

Boolean (default is false)

Used by unit tests to make sure the GemFire mcast-port has been configured to a non-default value.

gemfire.disk.recoverValues
Public: true

Boolean (default is true)

See org.apache.geode.internal.cache.SimpleDiskRegion.

  Whether to get the values from disk to memory on recovery

TBA

gemfire.EXPIRATIONS_CAUSE_CONFLICTS
Public: false

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)

gemfire.enableCpuTime
Public: false

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.

gemfire.enableContentionTime
Public: false

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.

gemfire.enableThreadStats
Public: false

Boolean (default is false)

This property causes the per thread stats to be collected. See java.lang.management.ThreadMXBean for more information.

gemfire.gateway-conserve-sockets-allowed
Public: true

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

gemfire.gateway-queue-no-ack
Public: true

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

gemfire.GatewayReceiver.ApplyRestries
Public: false

Boolean (default is false)

If true causes the GatewayReceiver will apply batches it has already received.

gemfire.gateway.ApplyRetries
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.tier.sockets.ServerConnection#APPLY_RETRIES.

TBA

gemfire.GetInitialImage.CHUNK_PERMITS
Public: false

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.

gemfire.GetInitialImage.MAX_PARALLEL_GIIS
Public: true

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.

gemfire.haltOnAssertFailure
Public: false

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.

gemfire.jg-can_bind_to_mcast_addr
Public: false

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.

gemfire.launcher.registerSignalHandlers
Public: false

Boolean (default is false)

Causes the code used by gfsh to launch a server or locator to install signal handlers using sun.misc.Signal.

gemfire.loadLibrary.debug
Public: false

Boolean (default is false)

See org.apache.geode.internal.PureJavaMode#debug.

TBA

gemfire.locatorXms
Public: false

String

See org.apache.geode.internal.gui.RemoteCommandManager#getLocatorStart.

See org.apache.geode.internal.gui.StartStopManager#startLocalLocator.

A JVM property, esp. "-Xms150m".

TBA

gemfire.locatorXmx
String

Public: false

See org.apache.geode.internal.gui.RemoteCommandManager#getLocatorStart.

See org.apache.geode.internal.gui.StartStopManager#startLocalLocator.

A JVM property, esp. "-Xmx400m"

TBA
gemfire.locators
Public: false

String

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.

gemfire.lru.maxSearchEntries
Public: false

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.

gemfire.order-pr-gets
Public: false

Boolean (default is false)

See org.apache.geode.internal.cache.partitioned.GetMessage#ORDER_PR_GETS.

TBA

gemfire.partitionedRegionRetryTimeout
Public: false

Integer (default is 60 * 60 * 1000)

See org.apache.geode.internal.cache.PartitionedRegion#retryTimeout

  The maximum milliseconds for retrying operations

TBA

gemfire.PRQueryProcessor.numThreads
Public: false

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

gemfire.pureJavaMode
Public: true

Boolean (default is false)

See org.apache.geode.internal.PureJavaMode class init.

Force use of "pure" Java mode (native libraries will not be loaded)

gemfire.SPECIAL_DURABLE
Public: false

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

gemfire.statsDisabled
Public: true

Boolean (default is false)

See org.apache.geode.distributed.internal.InternalDistributedSystem#statsDisabled.

TBA

gemfire.statusPollingDelay
Public: false

Long (default is 5000)

See org.apache.geode.admin.GemFireClientAdminTool#_statusPollingDelay.

Units are in milliseconds.

TBA

gemfire.syncWrites
Public: false

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

gemfire.TcpServer.MAX_POOL_SIZE
Public: false

Integer

   This property limits the number of threads that the locator will
	use for processing messages.

TBA

gemfire.TcpServer.BACKLOG
Public: false

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

gemfire.validateMessageSize
Public: false

Boolean (default is false)

See org.apache.geode.distributed.internal.DistributionConfig#VALIDATE.

TBA

gemfire.validateMessageSizeCeiling
Public: false

Integer (default is 8 * 1024 * 1024)

See org.apache.geode.distributed.internal.DistributionConfig#VALIDATE_CEILING.

TBA

gemfirePropertyFile
Public: true

String

See org.apache.geode.distributed.DistributedSystem#PROPERTY_FILE.

     The PROPERTY_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:
     
  1. the current directory
  2. the home directory
  3. the class path
Only the first file found will be used.

The default value of PROPERTY_FILE is "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.

@since GemFire 5.0

TBA

gemstone.MAX_BUCKET_GRAB_ATTEMPTS
Public: false

Integer (default is 20)

See org.apache.geode.internal.cache.PartitionedRegionDataStore.BucketRecoverer#grabBuckets.

TBA

gfAgentDebug
Public: false

Boolean

See org.apache.geode.admin.jmx.internal.AgentImpl#checkDebug.

  Enables mx4j tracing if Agent debugging is enabled.

TBA

gfAgentPropertyFile
Public: false

String

See org.apache.geode.admin.jmx.internal.AgentConfigImpl#retrievePropertyFile.

   The propertyFile 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:

  1. the current directory
  2. the home directory
  3. the class path
Only the first file found will be used.

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

gfc.propertyfile.init
Public: false

String

See org.apache.geode.internal.gui.Service#initProps().

This is name of a Properties file read at startup.

TBA

gfc.propertyfile.onclose
String

See org.apache.geode.internal.gui.Service#saveProps.

Public: false

This is the name of a Properties file to which some properties are saved a close.

TBA

install
Public: false

Boolean (default is false)

See org.apache.geode.internal.gui.NavigationPane#NavigationPane().

See org.apache.geode.internal.gui.Service#Service().

TBA

jta.VERBOSE
Public: false

Boolean

See org.apache.geode.internal.jta.GlobalTransaction#VERBOSE.

See org.apache.geode.internal.jta.TransactionManagerImpl#VERBOSE.

TBA

jta.defaultTimeout
Public: false

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?

mergelogs.TRIM_TIMESTAMPS
Public: false

Boolean (default is false)

See org.apache.geode.internal.LogFileParser#TRIM_TIMESTAMPS.

TBA

org.apache.commons.logging.log
Public: false

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.

osStatsDisabled
Public: false

Boolean (default is false)

See org.apache.geode.internal.GemFireStatSampler#osStatsDisabled.

TBA

p2p.DEBUG
Public: false

Boolean (default is false)

See org.apache.geode.internal.tcp.TCPConduit#DEBUG.

TBA

p2p.VERBOSE
Public: false

Boolean (default is false)

See org.apache.geode.internal.tcp.TCPConduit#QUIET.

TBA

p2p.backlog
Public: false

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

p2p.batchBufferSize
Public: false

Integer (default is 1024 * 1024)

See org.apache.geode.internal.tcp.Connection#BATCH_BUFFER_SIZE.

TBA

p2p.batchFlushTime
Public: false

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

p2p.batchSends
Public: false

Boolean (default is false)

See org.apache.geode.internal.tcp.Connection#BATCH_SENDS.

TBA

p2p.defaultLogLevel
Public: false

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

p2p.disableSocketWrite
Public: false

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

p2p.disconnectDelay
Public: false

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.

p2p.handshakeTimeoutMs
Public: false

Integer (default is 59000)

See org.apache.geode.internal.tcp.Connection#HANDSHAKE_TIMEOUT_MS.

TBA

p2p.HANDSHAKE_POOL_SIZE
Public: false

Integer (default is 10)

See org.apache.geode.internal.tcp.

p2p.joinTimeout
Public: false

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

p2p.lingerTime
Public: false

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.

p2p.listenerCloseTimeout
Public: false

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

p2p.maxGroupSenders
Public: false

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

gemfire.BufferPool.useHeapBuffers
Public: false

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

p2p.oldIO
Public: false

Boolean (default is false)

See org.apache.geode.internal.tcp.TCPConduit#useNIO.

If set, don't use java.nio.

p2p.readerBufferSize
Public: false

Integer (default is 32768)

See org.apache.geode.internal.tcp.Connection#INITIAL_CAPACITY.

TBA

p2p.tcpBufferSize
Public: false

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.

p2p.test.inhibitAcceptor
Public: false

Boolean (default is false)

See org.apache.geode.internal.tcp.TCPConduit#startAcceptor(int, int, InetAddress).

TBA

query.disableIndexes
Public: false

Boolean (default is false)

See org.apache.geode.cache.query.internal.index.IndexUtils#indexesEnabled.

TBA

remote.call.popup
Public: false

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

remote.call.timeout
Public: false

Integer (default is 1800)

See org.apache.geode.internal.admin.remote.AdminWaiters#getWaitTimeout.

Units are in seconds.

TBA

skipConnection
Public: false

Boolean (default is false)

Removed in Geode 1.0 with removal of deprecated Bridge classes.

TBA
slowStartTimeForTesting
Public: false

Long (default is 5000)

See org.apache.geode.internal.cache.tier.sockets.CacheClientProxy.MessageDispatcher#slowStartTimeForTesting.

Units are in milliseconds.

TBA

stats.archive-file
Public: false

String

See org.apache.geode.internal.SimpleStatSampler#archiveFileName.

This is a filename.

TBA

stats.disable
Public: false

Boolean (default is false)

See org.apache.geode.internal.LocalStatisticsFactory#statsDisabled.

TBA

stats.disk-space-limit
Public: false

Long (default is 1024 * 1024)

See org.apache.geode.internal.SimpleStatSampler#archiveDiskSpaceLimit.

TBA

stats.file-size-limit
Public: false

Long (default is 0)

See org.apache.geode.internal.SimpleStatSampler#archiveFileSizeLimit.

Units are in megabytes

TBA

stats.log-level
Public: false

String (See LogWriterImpl.levelNameToCode)

See org.apache.geode.internal.LocalStatisticsFactory#logLevel.

TBA

stats.name
Public: false

String

See org.apache.geode.internal.LocalStatisticsFactory#name.

TBA

stats.sample-rate
Public: false

Integer (default is 1000)

See org.apache.geode.internal.SimpleStatSampler#sampleRate.

Units are in milliseconds.

TBA

target.override
Public: false

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

tcpServerPort
Public: false

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

Other Jars

commons-logging-1.1.1.jar

Miscellaneous: org.apache.commons.logging.log.logName, where the name is the String passed to the SimpleLog constructor: This is a String used to set the logging level of the logger.
org.apache.commons.logging.log
Public: false

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.
org.apache.commons.logging.simplelog.dateformat
Public: false

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"

org.apache.commons.logging.simplelog.showDateTime
Public: false

Boolean (default is false)

See org.apache.commons.logging.impl.SimpleLog class init.

Include the current time in the log message

org.apache.commons.logging.simplelog.showLogName
Public: false

Boolean (default is false)

See org.apache.commons.logging.impl.SimpleLog class init.

"Include the instance name in the log message?"

org.apache.commons.logging.simplelog.showShortName
Public: false

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.

jta-1_0_1B.jar

TBA

rt.jar

TBA

sunrsasign.jar

TBA

jsse.jar

cert.provider.x509v1security
Public: false

String

X509Certificate implementation. See the JSSE documentation.

java.protocol.handler.pkgs
Public: false

String

HTTPS protocol implementation. See the JSSE documentation.

java.security.debug
Public: false

String

Geniric dynamic debug tracing support. See the JSSE documentation.

javax.net.debug
Public: false

String

JSSE-specific dynamic debug tracing support. See the JSSE documentation.

javax.net.ssl.keyStore
Public: false

String

default keystore. See the JSSE documentation.

javax.net.ssl.keyStoreType
Public: false

String

default keystore type. See the JSSE documentation.

javax.net.ssl.keyStorePassword
Public: false

String

default keystore password. See the JSSE documentation.

javax.net.ssl.trustStore>
Public: false

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.

javax.net.ssl.trustStorePassword
Public: false

String

default truststore password. See the JSSE documentation.

jce.jar

(none found)

charsets.jar

(none found)

localedata.jar

TBA

ldapsec.jar

TBA

sunjce_provider.jar

(none found)