Geode System Properties

Table of contents

  1. Miscellaneous
  2. Properties list
  3. Properties used by other Jars
    1. commons-logging-1.1.1.jar
    2. jsse.jar

These are the methods found that reference the system properties table.

  • 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)

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:

  • fullRegionName + _UNIT_BUFF_SIZE -- Integer

    “Asif: The minimum unit size of the Pool created. The ByteBuffer pools present at different indexes will be multiple of this size. Default unit buffer size is 1024”

  • fullRegionName + _MAX_POOL_SIZE -- Integer

    “The initial pool size . Default pool size is zero”

  • fullRegionName + _WAIT_TIME -- Integer

    “Asif: MAX time in milliseconds for which a thread will wait for a buffer to get freed up. If not available in that duration a buffer will be created on the fly. The timeout has no meaning if the max pool size is -1( no upper bound)”

Properties list, in Alphabetical Order

NameTypeDefault valueReferences
AdminDistributedSystemImpl.TIMEOUT_MSInteger60000See org.apache.geode.admin.internal.AdminDistributedSystemImpl#TIMEOUT_MS.
AvailablePort.fastRandomBooleanfalseSee 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.timeoutInteger2000See 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.
BridgeServer.HANDSHAKE_POOL_SIZEInteger4See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#HANDSHAKE_POOL_SIZE.
BridgeServer.MAXIMUM_CHUNK_SIZEInteger100See org.apache.geode.internal.cache.tier.sockets.BaseCommand#MAXIMUM_CHUNK_SIZE.
BridgeServer.MAX_INCOMING_DATAInteger-1See org.apache.geode.internal.cache.tier.sockets.BaseCommand#MAX_INCOMING_DATA. Maximum number of concurrent incoming client message bytes that a cache 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.
BridgeServer.MAX_INCOMING_MSGSInteger-1See org.apache.geode.internal.cache.tier.sockets.BaseCommand#MAX_INCOMING_MSGS. Maximum number of concurrent incoming client messages that a cache server will allow. Once a server is working on this number additional incoming client messages will wait until one of them completes or fails.
BridgeServer.SELECTORBooleanfalseSee org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#DEPRECATED_SELECTOR.Only used if max-threads == 0. This is for 5.0.2 backwards compatibility.Deprecated, since 5.1 use cache-server max-threads instead.
BridgeServer.SELECTOR_POOL_SIZEInteger16See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#DEPRECATED_SELECTOR_POOL_SIZE.Only used if max-threads == 0. This is for 5.0.2 backwards compatibility.Deprecated, since 5.1 use cache-server max-threads instead.
BridgeServer.SOCKET_BUFFER_SIZEInteger32768See 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.
BridgeServer.acceptTimeoutInteger2900See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#acceptTimeout.Sets the accept timeout (in milliseconds). This is how long a server will wait to get its first byte from a client it has just accepted.
BridgeServer.backlogInteger1280See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl constructor.This is the TCP/IP “accept” backlog for client/server communications.
BridgeServer.handShakeTimeoutInteger59000See org.apache.geode.internal.cache.tier.sockets.AcceptorImpl#handshakeTimeout.Sets the hand shake timeout (in milliseconds). This is how long a client will wait to hear back from a server.
DistributionManager.DISCONNECT_WAITLong10 * 1000See 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.
DistributionManager.INCOMING_QUEUE_LIMITInteger80000See org.apache.geode.distributed.internal.ClusterOperationExecutor#INCOMING_QUEUE_LIMIT.
DistributionManager.MAX_FE_THREADSIntegerMax of 100 and 16 * number of processorsSee org.apache.geode.distributed.internal.OperationExecutors#MAX_FE_THREADS.Maximum function execution threads.
DistributionManager.MAX_PR_THREADSIntegerMax of 200 and 32 * number of processorsSee org.apache.geode.distributed.internal.ClusterOperationExecutors#MAX_PR_THREADS.
DistributionManager.MAX_SERIAL_QUEUE_THREADInteger20See org.apache.geode.distributed.internal.ClusterOperationExecutors#MAX_SERIAL_QUEUE_THREAD.Max number of serial Queue executors, in case of multi-serial-queue executor
DistributionManager.MAX_THREADSInteger1000See org.apache.geode.distributed.internal.OperationExecutors#MAX_THREADS.
DistributionManager.MAX_WAITING_THREADSIntegerInteger.MAX_VALUESee org.apache.geode.distributed.internal.ClusterOperationExecutors#MAX_WAITING_THREADS.
DistributionManager.OptimizedUpdateByteLimitInteger2000See org.apache.geode.internal.cache.SearchLoadAndWriteProcessor#SMALL_BLOB_SIZE.
DistributionManager.SERIAL_QUEUE_BYTE_LIMITInteger40 * 1024 * 1024See org.apache.geode.distributed.internal.ClusterOperationExecutors#SERIAL_QUEUE_BYTE_LIMIT.
DistributionManager.SERIAL_QUEUE_SIZE_LIMITInteger20000See org.apache.geode.distributed.internal.ClusterOperationExecutors#SERIAL_QUEUE_SIZE_LIMIT.
DistributionManager.SERIAL_QUEUE_SIZE_THROTTLEIntegerSERIAL_QUEUE_SIZE_LIMIT * THROTTLE_PERCENTSee org.apache.geode.distributed.internal.ClusterOperationExecutors#SERIAL_QUEUE_THROTTLE.
DistributionManager.SERIAL_QUEUE_THROTTLE_PERCENTInteger75See org.apache.geode.distributed.internal.ClusterOperationExecutors#THROTTLE_PERCENT.
DistributionManager.TOTAL_SERIAL_QUEUE_BYTE_LIMITInteger80 * 1024 * 1024See org.apache.geode.distributed.internal.ClusterOperationExecutors#TOTAL_SERIAL_QUEUE_BYTE_LIMIT.
DistributionManager.TOTAL_SERIAL_QUEUE_THROTTLEIntegerSERIAL_QUEUE_BYTE_LIMIT * THROTTLE_PERCENTSee org.apache.geode.distributed.internal.ClusterOperationExecutors#TOTAL_SERIAL_QUEUE_THROTTLE.
DistributionManager.enqueueOrderedMessagesBooleanfalseSee org.apache.geode.distributed.internal.DistributionMessage#INLINE_PROCESS.
DistributionManager.requireAllStartupResponsesBooleanfalseSee org.apache.geode.distributed.internal.ClusterDistributionManager#sendStartupMessage.Fail distributed system join unless a startup response is received from all peers.
DistributionManager.singleSerialExecutorBooleanfalseSee org.apache.geode.distributed.internal.ClusterOperationExecutors#MULTI_SERIAL_EXECUTORS.Flag indicating whether to use single Serial-Executor thread or Multiple Serial-executor thread.
DistributionManager.syncEventsBooleanfalseSee org.apache.geode.distributed.internal.ClusterDistributionManager#SYNC_EVENTS.
DynamicRegionFactory.disablePersistenceBooleanfalseSee org.apache.geode.cache.DynamicRegionFactory#DISABLE_PERSIST_BACKUP.
DynamicRegionFactory.disableRegisterInterestBooleanfalseSee org.apache.geode.cache.DynamicRegionFactory#DISABLE_REGISTER_INTEREST.
DynamicRegionFactory.msDelayLong250See 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.
Gateway.EVENT_TIMEOUTInteger5 * 60 * 1000See org.apache.geode.internal.cache.wan.AbstractGatewaySender#EVENT_TIMEOUT.Units are in milliseconds.
GatewaySender.QUEUE_SIZE_THRESHOLDInteger5000See org.apache.geode.internal.cache.wan.AbstractGatewaySender#QUEUE_SIZE_THRESHOLD.The queue size threshold used to warn the user. If the queue reaches this size, log a warning.
GatewaySender.TOKEN_TIMEOUTInteger15000See org.apache.geode.internal.cachewan.AbstractGatewaySender#TOKEN_TIMEOUT.Timeout tokens in the unprocessedEvents map after this many milliseconds.
GetInitialImage.chunkSizeInteger500 * 1024See org.apache.geode.internal.cache.InitialImageOperation#CHUNK_SIZE_IN_BYTES.Maximum number of bytes to put in a single message
GrantorRequestProcessor.ELDER_CHANGE_SLEEPLong100See 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.
Locator.forceLocatorDMTypeBooleanfalseSee org.apache.geode.distributed.internal.InternalLocator#FORCE_LOCATOR_DM_TYPEUsed 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.inhibitDMBannerBooleanfalseSee org.apache.geode.distributed.internal.InternalLocator#INHIBIT_DM_BANNER.
StatArchiveReader.dumpBooleanfalseSee org.apache.geode.internal.StatArchiveReader constructor.
StatArchiveReader.dumpallBooleanfalseSee org.apache.geode.internal.StatArchiveReader.See org.apache.geode.internal.StatArchiveReader.SimpleValue.dump
ack-threshold-exceptionBooleanfalseSee org.apache.geode.distributed.internal.ReplyProcessor21#THROW_EXCEPTION_ON_TIMEOUT.
org.apache.geode.logging.internal.OSProcess.traceStringNo default valueSee org.apache.geode.logging.internal.OSProcess#bgexec(String[], File, File, boolean).If this property exists and has non-zero length (string content is not checked), additional information about the executed command is printed to System.out.
GemFire.ALWAYS_REPLICATE_UPDATESBooleanfalseSee org.apache.geode.internal.cache.AbstractUpdateOperation#ALWAYS_REPLICATE_UPDATES.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_TRANSACTIONSBooleanfalseSee org.apache.geode.internal.cache.TxManagerImpl#ALLOW_PERSISTENT_TRANSACTIONSA flag to allow persistent transactions.
gemfire.ASCII_STRINGSBooleanfalseSee org.apache.geode.internal.tcp.MsgStreamer#ASCII_STRINGS.See org.apache.geode.internal.BufferDataOutputStream#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.SAFEBooleanfalseSee apache.geode.pdx.internal.AutoSerializableManager.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.UNSAFEBooleanfalseSee apache.geode.pdx.internal.AutoSerializableManager.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.BucketAdvisor.getPrimaryTimeoutLong15000LSee org.apache.geode.internal.cache.BucketAdvisor#waitForNewPrimary.Add its value to the timeout for a new member to become primary. Units are in milliseconds.
gemfire.Cache.ASYNC_EVENT_LISTENERSBooleanfalseSee org.apache.geode.internal.cache.InternalCacheBuilder#USE_ASYNC_EVENT_LISTENERS_PROPERTY.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_LIMITInteger4096See org.apache.geode.internal.cache.GemFireCacheImpl#EVENT_QUEUE_LIMIT.
gemfire.Cache.defaultLockLeaseInteger120See org.apache.geode.internal.cache.GemFireCacheImpl#DEFAULT_LOCK_LEASE.The default duration (in seconds) of a lease on a distributed lock.
gemfire.Cache.defaultLockTimeoutInteger60See org.apache.geode.internal.cache.GemFireCacheImpl#DEFAULT_LOCK_TIMEOUT.The default number of seconds to wait for a distributed lock.
gemfire.Cache.defaultSearchTimeoutInteger300See org.apache.geode.internal.cache.GemFireCacheImpl#DEFAULT_SEARCH_TIMEOUT.The default amount of time to wait for a netSearch to complete.Units are in seconds.
gemfire.Cache.startSerialNumberInteger1See org.apache.geode.distributed.internal.DistributionAdvisor#START_SERIAL_NUMBER.Specifies the starting serial number for the serialNumberSequencer.
gemfire.CacheDistributionAdvisor.rolloverThresholdInteger1000See org.apache.geode.distributed.internal.DistributionAdvisor#ROLLOVER_THRESHOLD.Used to compare profile versioning numbers against Integer.MAX_VALUE Integer.MIN_VALUE to determine if a rollover has occurred.
gemfire.CapacityInteger230000See org.apache.geode.internal.cache.ha.HARegionQueueAttributes#BLOCKING_QUEUE_CAPACITY.
gemfire.DEFAULT_MAX_OPLOG_SIZELong1024LSee org.apache.geode.cache.DiskStoreFactory#DEFAULT_MAX_OPLOG_SIZE.See org.apache.geode.internal.cache.DiskWriteAttributesImpl#DEFAULT_MAX_OPLOG_SIZE.Default max in bytes
gemfire.DLockService.automateFreeResourcesBooleanfalseSee org.apache.geode.distributed.internal.locks.DLockService#AUTOMATE_FREE_RESOURCES
gemfire.DLockService.LockGrantorId.rolloverMarginInteger10000See org.apache.geode.distributed.internal.locks.LockGrantorId#ROLLOVER_MARGIN.
gemfire.DLockService.debug.nonGrantorDestroyLoopBooleanfalseSee org.apache.geode.distributed.internal.locks.DLockService#DEBUG_NONGRANTOR_DESTROY_LOOP.
gemfire.DLockService.debug.nonGrantorDestroyLoopCountInteger20See org.apache.geode.distributed.internal.locks.DLockService#DEBUG_NONGRANTOR_DESTROY_LOOP_COUNT.
gemfire.DLockService.notGrantorSleepLong100See org.apache.geode.distributed.internal.locks.DLockService#NOT_GRANTOR_SLEEP.Units are in milliseconds.
gemfire.DistributedLockService.startSerialNumberInteger1See org.apache.geode.distributed.internal.locks.DLockService#START_SERIAL_NUMBER.Specifies the starting serial number for the serialNumberSequencer.
gemfire.DO_EXPENSIVE_VALIDATIONSBooleanfalseSee org.apache.geode.internal.cache.LocalRegion#DO_EXPENSIVE_VALIDATIONS.
gemfire.DistributionAdvisor.startVersionNumberInteger1See org.apache.geode.distributed.internal.DistributionAdvisor#START_VERSION_NUMBER.Specifies the starting version number for the profileVersionSequencer.
gemfire.EXPIRY_THREADSInteger0See org.apache.geode.internal.cache.ExpiryTask class init
gemfire.EXPIRY_UNITS_MSBooleanfalseSee org.apache.geode.internal.cache.LocalRegion#EXPIRY_MS_PROPERTY.Used by unit tests to set expiry to milliseconds instead of the default seconds. Used in ExpiryTask.
gemfire.IDLE_THREAD_TIMEOUTInteger30000 * 60See org.apache.geode.distributed.internal.FunctionExecutionPooledExecutor constructor.See org.apache.geode.internal.logging.CoreLoggingExecutors#getIdleThreadTimeoutMillisUnits are in milliseconds.
gemfire.locator-load-imbalance-thresholdFloat10.0See org.apache.geode.distributed.internal.LocatorLoadSnapshot#LOAD_IMBALANCE_THRESHOLD_PROPERTY_NAMESets 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.memoryEventToleranceInteger0See org.apache.geode.internal.cache.control.MemoryThresholds#memoryStateChangeToleranceNumber of eviction or critical state changes that have to occur before the event is delivered.The default is 0 so we will change states immediately by default.
gemfire.MAX_PENDING_CANCELSInteger10000See org.apache.geode.internal.cache.ExpirationScheduler#MAX_PENDING_CANCELS.
gemfire.MAXIMUM_SHUTDOWN_PEEKSInteger50See org.apache.geode.internal.cache.tier.sockets.CacheClientProxy#MAXIMUM_SHUTDOWN_PEEKS.The number of times to peek on shutdown before giving up and shutting down.
gemfire.MIN_BUCKET_SIZEInteger1See org.apache.geode.internal.cache.partitioned.SizedBasedLoadProbe.#MIN_BUCKET_SIZEAllows setting the minimum bucket size to be used during rebalance
gemfire.DISABLE_MOVE_PRIMARIES_ON_STARTUPBooleanfalseSee org.apache.geode.internal.cache.PRHARedundancyProvider#scheduleRedundancyRecoverySee org.apache.geode.internal.cache.control.RebalanceOperationImpl#scheduleRebalanceIf true then pr primary buckets will not be balanced when a new member is started.
gemfire.MessageTimeToLiveInteger180See org.apache.geode.internal.cache.ha.HARegionQueue#getHARegionQueueInstance.Constant used to set region entry expiry time using system property.Units are in seconds.
gemfire.ON_DISCONNECT_CLEAR_PDXTYPEIDSBooleanfalseSee org.apache.geode.cache.client.internal.PoolImpl#ON_DISCONNECT_CLEAR_PDXTYPEIDSClear pdxType ids when client disconnects from servers
gemfire.PRDebugBooleanfalseSee org.apache.geode.internal.admin.remote.RemoteCacheInfo constructor.See org.apache.geode.internal.admin.remote.RootRegionResponse#create(DistributionManager, InternalDistributedMember).See org.apache.geode.internal.cache.FixedPartitionAttributesImpl#toString.See org.apache.geode.internal.cache.PartitionedRegionDataStore#createBucketRegion(int).See org.apache.geode.internal.cache.PartitionedRegionHelper#getPRRoot(InternalCache, boolean).See org.apache.geode.internal.cache.PartitionedRegionHelper#logForDataLoss(PartitionedRegion,int,String).
gemfire.PREFER_SERIALIZEDBooleanfalseSee org.apache.geode.internal.cache.CachedDeserializableFactory#PREFER_DESERIALIZED.Enable storing the values in serialized form
gemfire.PRSanityCheckDisabledBooleanfalseSee org.apache.geode.internal.cache.partitioned.PRSanityCheckMessage#schedule.
gemfire.PRSanityCheckIntervalInteger5000See org.apache.geode.internal.cache.partitioned.PRSanityCheckMessage#schedule.Units are in milliseconds.
gemfire.PartitionedRegionRandomSeedLongNanoTimer.getTime()See org.apache.geode.internal.cache.PartitionedRegion#RANDOM.Seed for the random number generator in this class.
gemfire.Query.COMPILED_QUERY_CLEAR_TIMEInteger10 * 60 * 1000See org.apache.geode.cache.query.internal.DefaultQuery.#COMPILED_QUERY_CLEAR_TIMEFrequency of clean up compiled queries
gemfire.Query.VERBOSEBooleanfalseSee org.apache.geode.cache.query.internal.DefaultQuery.#QUERY_VERBOSEEnable verbose logging in the query execution
gemfire.QueryService.QueryHeterogeneousObjectsBooleantrueSee org.apache.geode.cache.query.internal.DefaultQueryService.#QUERY_HETEROGENEOUS_OBJECTSAllow query on region with heterogeneous objects
gemfire.randomizeOnMemberBooleanfalseSee org.apache.geode.internal.cache.execute.InternalFunctionExecutionServiceImpl.#RANDOM_onMemberWhen set, onMember execution will be executed on a random member.
gemfire.RegionAdvisor.volunteeringThreadCountInteger1See org.apache.geode.internal.cache.partitioned.RegionAdvisor#VOLUNTERING_THREAD_COUNT.Number of threads allowed to concurrently volunteer for bucket primary.
gemfire.VM_OWNERSHIP_WAIT_TIMELongLong.MAX_VALUESee org.apache.geode.internal.cache.PartitionedRegion#VM_OWNERSHIP_WAIT_TIMETime to wait for for acquiring distributed lock ownership. Time is specified in milliseconds.
gemfire.bridge.disableShufflingOfEndpointsBooleanfalseSee org.apache.geode.cache.cient.internal.ExplicitConnectionSourceImpl#DISABLE_SHUFFLING.A debug flag, which can be toggled by tests to disable/enable shuffling of the endpoints list.
gemfire.bridge.suppressIOExceptionLoggingBooleanfalseSee org.apache.geode.internal.cache.tier.sockets.BaseCommand#SUPPRESS_IO_EXCEPTION_LOGGING.Whether to suppress logging of IOExceptions.
gemfire.BridgeServer.FORCE_LOAD_UPDATE_FREQUENCYInteger10See org.apache.geode.internal.cache.CacheServerImpl.#FORCE_LOAD_UPDATE_FREQUENCYHow often to force a CacheServer load message to be sent
gemfire.BucketRegion.alwaysFireLocalListenersBooleanfalseSee org.apache.geode.internal.cache.BucketRegion.#FORCE_LOCAL_LISTENERS_INVOCATIONEnable invocation of listeners in both primary and secondary buckets
gemfire.Cache.MAX_QUERY_EXECUTION_TIMEInteger-1See org.apache.geode.internal.cache.GemFireCacheImpl.#MAX_QUERY_EXECUTION_TIMELimit the max query execution time (ms)
gemfire.CLIENT_FUNCTION_TIMEOUTInteger0See org.apache.geode.internal.cache.execute.AbstractExecution#CLIENT_FUNCTION_TIMEOUT_SYSTEM_PROPERTYTimeout to set for client function execution
gemfire.clientSocketFactoryStringemptySee org.apache.geode.internal.net.SocketCreator#initializeClientSocketFactoryNon-standard Socket creator
gemfire.cq.EXECUTE_QUERY_DURING_INITBooleantrueSee org.apache.geode.cache.query.cq.internal.CqServiceImpl.#EXECUTE_QUERY_DURING_INITWhen set to false, avoid query execution during CQ when initial results are not required
gemfire.disableAccessTimeUpdateOnPutBooleanfalseSee org.apache.geode.internal.cache.entries.AbstractRegionEntry.#DISABLE_ACCESS_TIME_UPDATE_ON_PUTWhether to disable last access time update when a put occurs.
gemfire.disable-event-old-valueBooleanDefault: falseSee 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.
gemfire.disablePartitionedRegionBucketAckBooleanfalseSee org.apache.geode.internal.cache.PartitionedRegion.#DISABLE_SECONDARY_BUCKET_ACKEnable no-ack replication in bucket regions
gemfire.disableShutdownHookBooleanfalseSee org.apache.geode.distributed.internal.InternalDistributedSystem#DISABLE_SHUTDOWN_HOOK_PROPERTYIf true then the shutdown hooks of the DistributedSystem, Locator, and Agent are not run on shutdown. This was added for bug 38407.
gemfire.disallowMcastDefaultsBooleanfalseSee org.apache.geode.distributed.internal.DistributionConfigImpl#checkForDisallowedDefaultsUsed by unit tests to make sure the Geode mcast-port has been configured to a non-default value.
gemfire.disk.recoverValuesBooleantrueSee org.apache.geode.internal.cache.DiskStoreImpl#RECOVER_VALUE_PROPERTY_NAME.Whether to get the values from disk to memory on recovery
gemfire.enableCpuTimeBooleanfalseSee org.apache.geode.internal.stats50.VMStats50This 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.enableContentionTimeBooleanfalseSee org.apache.geode.internal.stats50.VMStats50This 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.enableThreadStatsBooleanfalseSee org.apache.geode.internal.stats50.VMStats50This property causes the per thread stats to be collected. See java.lang.management.ThreadMXBean for more information.
gemfire.gateway-queue-no-ackBooleanfalseSee org.apache.geode.internal.cache.wan.serial.SerialGatewaySenderQueue#NO_ACK.Whether the Gateway queue should be no-ack instead of ack.
gemfire.GatewayReceiver.ApplyRetriesBooleanfalseSee org.apache.geode.cache.wan.GatewayReceiver#APPLY_RETRIESIf true causes the GatewayReceiver will apply batches it has already received.
gemfire.GetInitialImage.CHUNK_PERMITSInteger16See org.apache.geode.internal.cache.InitialImageOperation.#CHUNK_PERMITSAllowed number of in-flight initial image chunks. This property controls how many requests for GII chunks can be handled simultaneously.
gemfire.GetInitialImage.MAX_PARALLEL_GIISInteger5See 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.haltOnAssertFailureBooleanfalseSee 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.launcher.registerSignalHandlersBooleanfalseSee org.apache.geode.distributed.AbstractLauncher.SIGNAL_HANDLER_REGISTRATION_SYSTEM_PROPERTYCauses the code used by gfsh to launch a server or locator to install signal handlers using sun.misc.Signal.
gemfire.locatorsStringSee org.apache.geode.distributed.internal.InternalLocator#startDistributedSystem.If this property is not found in gemfire.properties, the system property of the same name is used.
gemfire.lru.maxSearchEntriesInteger-1See org.apache.geode.internal.lang.SystemPropertyHelper#EVICTION_SEARCH_MAX_ENTRIES.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-getsBooleanfalseSee org.apache.geode.internal.cache.partitioned.GetMessage#ORDER_PR_GETS.
gemfire.partitionedRegionRetryTimeoutInteger60 * 60 * 1000See org.apache.geode.internal.cache.PartitionedRegion#retryTimeoutThe maximum milliseconds for retrying operations
gemfire.PRQueryProcessor.numThreadsInteger1See org.apache.geode.internal.cache.PRQueryProcessor#NUM_THREADSThe 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.
gemfire.SPECIAL_DURABLEBooleanfalseSee org.apache.geode.cache.client.internal.PoolImpl constructor.See org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID constructor.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.statsDisabledBooleanfalseSee org.apache.geode.distributed.internal.InternalDistributedSystem#statsDisabled.
gemfire.syncWritesBooleanfalseSee 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)
gemfire.TcpServer.MAX_POOL_SIZEInteger100See org.apache.geode.distributed.internal.InternalLocator#MAX_POOL_SIZEThis property limits the number of threads that the locator will use for processing messages.
gemfire.TcpServer.BACKLOGIntegerValue of p2p.backlog propertySee org.apache.geode.distributed.internal.tcpserver.TcpServer#backlogLimitThis property establishes a Locator's TCP/IP “accept” backlog for locator communications.
gemfire.validateMessageSizeBooleanfalseSee org.apache.geode.distributed.internal.DistributionConfig#VALIDATE.
gemfirePropertyFileStringgemfire.propertiesSee org.apache.geode.distributed.DistributedSystem#PROPERTIES_FILE_PROPERTY.The PROPERTIES_FILE_PROPERTY is the system property that can be used to specify the name of the properties file that the connect method will check for when it looks for a properties file. Unless the value specifies the fully qualified path to the file, the file will be searched for, in order, in the following directories:- the current directory
- the home directory
- the class pathOnly the first file found will be used. The default value is gemfire.properties. However if the PROPERTIES_FILE_PROPERTY is set then its value will be used instead of the default. 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.
gfAgentDebugBooleanfalseSee org.apache.geode.admin.jmx.internal.AgentImpl#checkDebug.Enables mx4j tracing if Agent debugging is enabled.
gfAgentPropertyFileStringagent.propertiesSee 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:- the current directory
- the home directory
- the class pathOnly 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.
jta.VERBOSEBooleanfalseSee org.apache.geode.internal.jta.GlobalTransaction#VERBOSE.See org.apache.geode.internal.jta.TransactionManagerImpl#VERBOSE.
jta.defaultTimeoutInteger600See org.apache.geode.internal.jta.TransactionManagerImpl#DEFAULT_TRANSACTION_TIMEOUT.Units are in seconds.
mergelogs.TRIM_TIMESTAMPSBooleanfalseSee org.apache.geode.internal.LogFileParser#TRIM_TIMESTAMPS.
org.apache.commons.logging.logStringorg.apache.commons.logging.impl.SimpleLogSee 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.
org.apache.geode.internal.net.ssl.configStringSee org.apache.geode.management.internal.ContextAwareSSLRMIClientSocketFactory#createSocket()In gfsh the ssl config is stored within the org.apache.geode.internal.net.ssl.config system property
osStatsDisabledBooleanfalseSee org.apache.geode.internal.HostStatSampler#osStatsDisabled.
p2p.backlogInteger1000 (but limited by OS somaxconn setting)See org.apache.geode.distributed.internal.tcpserver.TcpServer#p2pBacklog.backlog is the TCP/IP “accept” backlog configuration parameter for cluster communications
p2p.batchBufferSizeInteger1024 * 1024See org.apache.geode.internal.tcp.Connection#BATCH_BUFFER_SIZE.
p2p.batchFlushTimeInteger50See org.apache.geode.internal.tcp.Connection#BATCH_FLUSH_MS.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)
p2p.batchSendsBooleanfalseSee org.apache.geode.internal.tcp.Connection#BATCH_SENDS.
p2p.disableSocketWriteBooleanfalseSee 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
p2p.disconnectDelayInteger3000See org.apache.geode.distributed.internal.DistributionImpl#destroyMember.Workaround for bug 34010: small pause inserted before closing reader threads for a departed member.Units are milliseconds.
p2p.handshakeTimeoutMsInteger59000See org.apache.geode.internal.tcp.Connection#HANDSHAKE_TIMEOUT_MS.
p2p.joinTimeoutLong60000 for a server and 24000 for a locatorSee org.apache.geode.distributed.internal.membership.adapter.ServiceConfig constructor.Establishes the timeout for waiting for a join response when connecting to the cluster. Units are in milliseconds.
p2p.listenerCloseTimeoutInteger60000See org.apache.geode.internal.tcp.TCPConduit#LISTENER_CLOSE_TIMEOUT.Max amount of time (ms) to wait for listener threads to stop
gemfire.BufferPool.useHeapBuffersBooleanfalseSee 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.
p2p.oldIOBooleanfalseSee org.apache.geode.internal.tcp.TCPConduit#init.Deprecated. If set, a warning message is logged saying it is currently not supported. This property was used for not using java.nio.
p2p.tcpBufferSizeInteger32768See org.apache.geode.internal.tcp.TCPConduit#parseProperties.Any value smaller than gemfire.SMALL_BUFFER_SIZE will be set to gemfire.SMALL_BUFFER_SIZE.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.inhibitAcceptorBooleanfalseSee org.apache.geode.internal.tcp.TCPConduit#startAcceptor.
query.disableIndexesBooleanfalseSee org.apache.geode.cache.query.internal.index.IndexUtils#indexesEnabled.
remote.call.timeoutInteger1800See org.apache.geode.internal.admin.remote.AdminWaiters#getWaitTimeout.Units are in seconds.
skipConnectionBooleanfalseRemoved in Geode 1.0 with removal of deprecated Bridge classes.
slowStartTimeForTestingLong5000See org.apache.geode.internal.cache.tier.sockets.MessageDispatcher#run().Units are in milliseconds.
stats.archive-fileStringstats.gfsSee org.apache.geode.internal.statistics.SimpleStatSampler#archiveFileName.
stats.disableBooleanfalseSee org.apache.geode.internal.statistics.LocalStatisticsFactory#statsDisabled.
stats.disk-space-limitLong0See org.apache.geode.internal.statistics.SimpleStatSampler#archiveDiskSpaceLimit.
stats.file-size-limitLong0See org.apache.geode.internal.SimpleStatSampler#archiveFileSizeLimit.Units are in megabytes
stats.nameStringThread.currentThread().getName()See org.apache.geode.internal.LocalStatisticsFactory#initName.
stats.sample-rateInteger1000See org.apache.geode.internal.SimpleStatSampler#sampleRate.Units are in milliseconds.
tcpServerPortIntegertcp-port property in the distribution configSee org.apache.geode.distributed.internal.direct.DirectChannel#DirectChannel(MembershipManager, DistributedMembershipListener, DistributionConfig, LogWriter, Properties).
WRITE_BUF_SIZEInteger32768 (disk store --write-buffer-size option default value)Sets the disk store write buffer size. If set, it takes precedence over the disk store --write-buffer-size option value.See org.apache.geode.internal.cache.Oplog#allocateWriteBuf(OplogFile prevOlf)
See org.apache.geode.internal.cache.OverflowOplog#allocateWriteBuf(OverflowOplog previous)Units are in bytes.

Properties used by other Jars

ToDo: Following jars were in the previous version if this document, they should be reviewed:

  • jta-1_0_1B.jar
  • rt.jar
  • sunrsasign.jar
  • jce.jar
  • charsets.jar
  • localedata.jar
  • ldapsec.jar
  • sunjce_provider.jar

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.

See http://commons.apache.org/proper/commons-logging/apidocs/org/apache/commons/logging/impl/SimpleLog.html for more information .

NameTypeDefault valueReferences
org.apache.commons.logging.logStringorg.apache.commons.logging.impl.SimpleLogSee org.apache.geode.admin.jmx.internal.AgentImplSee org.apache.commons.logging.impl.LogFactoryImpl#LOG_PROPERTYThe name of the system property identifying our Log implementation class.
org.apache.commons.logging.simplelog.dateTimeFormatStringyyyy/MM/dd HH:mm:ss:SSS zzzThe date and time format to be used in the output messages. The pattern describing the date and time format is the same that is used in java.text.SimpleDateFormat.
org.apache.commons.logging.simplelog.showdatetimeBooleanfalseSet to true if you want the current date and time to be included in output messages
org.apache.commons.logging.simplelog.showlognameBooleanfalseSet to true if you want the Log instance name to be included in output messages
org.apache.commons.logging.simplelog.showShortLognameStringtrueSet to true if you want the last component of the name to be included in output messages. Default to true - otherwise we'll be lost in a flood of messages without knowing who sends them.

jsse.jar

See the JSSE documentation for more information.

NameTypeReferences
cert.provider.x509v1securityStringX509Certificate implementation.
java.protocol.handler.pkgsStringHTTPS protocol implementation.
java.security.debugStringGeneric dynamic debug tracing support.
javax.net.debugStringJSSE-specific dynamic debug tracing support.
javax.net.ssl.keyStoreStringSee org.apache.geode.internal.net.SSLConfigurationFactory#JAVAX_KEYSTOREDefault keystore.
javax.net.ssl.keyStoreTypeStringSee org.apache.geode.internal.net.SSLConfigurationFactory#JAVAX_KEYSTORE_TYPEDefault keystore type.
javax.net.ssl.keyStorePasswordStringSee org.apache.geode.internal.net.SSLConfigurationFactory#JAVAX_KEYSTORE_PASSWORDDefault keystore password.
javax.net.ssl.trustStoreStringSee org.apache.geode.internal.net.SSLConfigurationFactory#JAVAX_TRUSTSTOREIf 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.trustStorePasswordStringSee org.apache.geode.internal.net.SSLConfigurationFactory#JAVAX_TRUSTSTORE_PASSWORDDefault truststore password.