You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by ud...@apache.org on 2016/07/22 00:19:51 UTC

[04/26] incubator-geode git commit: GEODE-420: Initial Alias defintion and removal of deprecated SSL-ENABLED properties

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c27b85c6/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionConfigImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionConfigImpl.java
index 6ac100c..c7b7daf 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionConfigImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/distributed/internal/DistributionConfigImpl.java
@@ -48,85 +48,114 @@ import com.gemstone.gemfire.memcached.GemFireMemcachedServer;
 /**
  * Provides an implementation of <code>DistributionConfig</code> that
  * knows how to read the configuration file.
- *
- * <P>
- *
+ * <p>
+ * <p>
+ * <p>
  * Note that if you add a property to this interface, should should
  * update  the {@link
  * #DistributionConfigImpl(DistributionConfig) copy constructor}.
- *
  * @see InternalDistributedSystem
- *
- *
  * @since GemFire 2.1
  */
-public class DistributionConfigImpl
-  extends AbstractDistributionConfig
-  implements Serializable {
+public class DistributionConfigImpl extends AbstractDistributionConfig implements Serializable {
 
   private static final long serialVersionUID = 4096393792893825167L;
 
-  /** The name of the distribution manager/shared memory connection */
+  /**
+   * The name of the distribution manager/shared memory connection
+   */
   private String name = DEFAULT_NAME;
 
-  /** The tcp/ip port used for distribution */
+  /**
+   * The tcp/ip port used for distribution
+   */
   private int tcpPort = DEFAULT_TCP_PORT;
 
-  /** The multicast port used for distribution */
+  /**
+   * The multicast port used for distribution
+   */
   private int mcastPort = DEFAULT_MCAST_PORT;
 
-  /** The multicast ttl used for distribution */
+  /**
+   * The multicast ttl used for distribution
+   */
   private int mcastTtl = DEFAULT_MCAST_TTL;
 
   private int socketLeaseTime = DEFAULT_SOCKET_LEASE_TIME;
   private int socketBufferSize = DEFAULT_SOCKET_BUFFER_SIZE;
   private boolean conserveSockets = DEFAULT_CONSERVE_SOCKETS;
 
-  /** Comma-delimited list of the application roles performed by this member. */
+  /**
+   * Comma-delimited list of the application roles performed by this member.
+   */
   private String roles = DEFAULT_ROLES;
 
-  /** The multicast address used for distribution */
+  /**
+   * The multicast address used for distribution
+   */
   private InetAddress mcastAddress = DEFAULT_MCAST_ADDRESS;
 
-  /** The address server socket's should listen on */
+  /**
+   * The address server socket's should listen on
+   */
   private String bindAddress = DEFAULT_BIND_ADDRESS;
 
-  /** The address server socket's in a  client-server topology should listen on */
+  /**
+   * The address server socket's in a  client-server topology should listen on
+   */
   private String serverBindAddress = DEFAULT_SERVER_BIND_ADDRESS;
 
-  /** The locations of the distribution locators */
+  /**
+   * The locations of the distribution locators
+   */
   private String locators = DEFAULT_LOCATORS;
-  
-  /** The amount of time to wait for a locator to appear when starting up */
+
+  /**
+   * The amount of time to wait for a locator to appear when starting up
+   */
   private int locatorWaitTime;
-  
-  /** The name of the log file */
+
+  /**
+   * The name of the log file
+   */
   private File logFile = DEFAULT_LOG_FILE;
-  
+
   protected File deployWorkingDir = DEFAULT_DEPLOY_WORKING_DIR;
-  
-  /** The level at which log messages are logged
-   *
+
+  /**
+   * The level at which log messages are logged
    * @see com.gemstone.gemfire.internal.logging.LogWriterImpl#levelNameToCode(String)
    */
   protected int logLevel = DEFAULT_LOG_LEVEL;
 
-  /** bind-address and host of locator to start */
+  /**
+   * bind-address and host of locator to start
+   */
   private String startLocator = DEFAULT_START_LOCATOR;
 
-  /** port of locator to start.  use bind-address as host name */
+  /**
+   * port of locator to start.  use bind-address as host name
+   */
   private int startLocatorPort;
 
-  /** Is statistic sampling enabled? */
+  /**
+   * Is statistic sampling enabled?
+   */
   protected boolean statisticSamplingEnabled = DEFAULT_STATISTIC_SAMPLING_ENABLED;
 
-  /** The rate (in milliseconds) at which statistics are sampled */
+  /**
+   * The rate (in milliseconds) at which statistics are sampled
+   */
   protected int statisticSampleRate = DEFAULT_STATISTIC_SAMPLE_RATE;
 
-  /** The name of the file to which statistics should be archived */
+  /**
+   * The name of the file to which statistics should be archived
+   */
   protected File statisticArchiveFile = DEFAULT_STATISTIC_ARCHIVE_FILE;
 
-  /** The amount of time to wait for a ACK message */
+  /**
+   * The amount of time to wait for a ACK message
+   */
   private int ackWaitThreshold = DEFAULT_ACK_WAIT_THRESHOLD;
 
   /**
@@ -136,7 +165,9 @@ public class DistributionConfigImpl
    */
   private int ackForceDisconnectThreshold = DEFAULT_ACK_SEVERE_ALERT_THRESHOLD;
 
-  /** The name of an XML file used to initialize the cache */
+  /**
+   * The name of an XML file used to initialize the cache
+   */
   private File cacheXmlFile = Boolean.getBoolean(InternalLocator.FORCE_LOCATOR_DM_TYPE) ? new File("") : DEFAULT_CACHE_XML_FILE;
 
   protected int archiveDiskSpaceLimit = DEFAULT_ARCHIVE_DISK_SPACE_LIMIT;
@@ -144,55 +175,71 @@ public class DistributionConfigImpl
   protected int logDiskSpaceLimit = DEFAULT_LOG_DISK_SPACE_LIMIT;
   protected int logFileSizeLimit = DEFAULT_LOG_FILE_SIZE_LIMIT;
 
-  protected boolean sslEnabled = DEFAULT_SSL_ENABLED;
-  protected String sslProtocols = DEFAULT_SSL_PROTOCOLS;
-  protected String sslCiphers = DEFAULT_SSL_CIPHERS;
-  protected boolean sslRequireAuthentication = DEFAULT_SSL_REQUIRE_AUTHENTICATION;
-
-  protected boolean clusterSSLEnabled = DEFAULT_CLUSTER_SSL_ENABLED;
-  protected String clusterSSLProtocols = DEFAULT_CLUSTER_SSL_PROTOCOLS;
-  protected String clusterSSLCiphers = DEFAULT_CLUSTER_SSL_CIPHERS;
-  protected boolean clusterSSLRequireAuthentication = DEFAULT_CLUSTER_SSL_REQUIRE_AUTHENTICATION;
-  protected String clusterSSLKeyStore = DEFAULT_CLUSTER_SSL_KEYSTORE;
-  protected String clusterSSLKeyStoreType = DEFAULT_CLUSTER_SSL_KEYSTORE_TYPE;
-  protected String clusterSSLKeyStorePassword = DEFAULT_CLUSTER_SSL_KEYSTORE_PASSWORD;
-  protected String clusterSSLTrustStore = DEFAULT_CLUSTER_SSL_TRUSTSTORE;
-  protected String clusterSSLTrustStorePassword = DEFAULT_CLUSTER_SSL_TRUSTSTORE_PASSWORD;
-  
-  /** multicast send buffer size, in bytes */
+  private boolean clusterSSLEnabled = DEFAULT_CLUSTER_SSL_ENABLED;
+  private String clusterSSLProtocols = DEFAULT_CLUSTER_SSL_PROTOCOLS;
+  private String clusterSSLCiphers = DEFAULT_CLUSTER_SSL_CIPHERS;
+  private boolean clusterSSLRequireAuthentication = DEFAULT_CLUSTER_SSL_REQUIRE_AUTHENTICATION;
+  private String clusterSSLKeyStore = DEFAULT_CLUSTER_SSL_KEYSTORE;
+  private String clusterSSLKeyStoreType = DEFAULT_CLUSTER_SSL_KEYSTORE_TYPE;
+  private String clusterSSLKeyStorePassword = DEFAULT_CLUSTER_SSL_KEYSTORE_PASSWORD;
+  private String clusterSSLTrustStore = DEFAULT_CLUSTER_SSL_TRUSTSTORE;
+  private String clusterSSLTrustStorePassword = DEFAULT_CLUSTER_SSL_TRUSTSTORE_PASSWORD;
+  private String clusterSSLAlias = DEFAULT_CLUSTER_SSL_ALIAS;
+
+  /**
+   * multicast send buffer size, in bytes
+   */
   protected int mcastSendBufferSize = DEFAULT_MCAST_SEND_BUFFER_SIZE;
-  /** multicast receive buffer size, in bytes */
+  /**
+   * multicast receive buffer size, in bytes
+   */
   protected int mcastRecvBufferSize = DEFAULT_MCAST_RECV_BUFFER_SIZE;
-  /** flow-of-control parameters for multicast messaging */
+  /**
+   * flow-of-control parameters for multicast messaging
+   */
   protected FlowControlParams mcastFlowControl = DEFAULT_MCAST_FLOW_CONTROL;
 
-  /** datagram socket send buffer size, in bytes */
+  /**
+   * datagram socket send buffer size, in bytes
+   */
   protected int udpSendBufferSize = DEFAULT_UDP_SEND_BUFFER_SIZE;
-  /** datagram socket receive buffer size, in bytes */
+  /**
+   * datagram socket receive buffer size, in bytes
+   */
   protected int udpRecvBufferSize = DEFAULT_UDP_RECV_BUFFER_SIZE;
-  /** max datagram message size, in bytes.  This should be < 64k */
+  /**
+   * max datagram message size, in bytes.  This should be < 64k
+   */
   protected int udpFragmentSize = DEFAULT_UDP_FRAGMENT_SIZE;
 
-  /** whether tcp/ip sockets should be disabled */
+  /**
+   * whether tcp/ip sockets should be disabled
+   */
   protected boolean disableTcp = DEFAULT_DISABLE_TCP;
 
-  /** whether time statistics should be enabled for the distributed system */
+  /**
+   * whether time statistics should be enabled for the distributed system
+   */
   protected boolean enableTimeStatistics = DEFAULT_ENABLE_TIME_STATISTICS;
 
-  /** member contact timeout, in milliseconds, for failure detection */
+  /**
+   * member contact timeout, in milliseconds, for failure detection
+   */
   protected int memberTimeout = DEFAULT_MEMBER_TIMEOUT;
-  
-  /** the Jgroups port ranges allowed */
+
+  /**
+   * the Jgroups port ranges allowed
+   */
   protected int[] membershipPortRange = DEFAULT_MEMBERSHIP_PORT_RANGE;
-  
+
   /**
    * Max wait time for the member before reconnecting to the DS in case of
    * required role loss.
-   * */
+   */
   private int maxWaitTimeForReconnect = DEFAULT_MAX_WAIT_TIME_FOR_RECONNECT;
   /**
    * Max number of tries allowed for reconnect in case of required role loss.
-   * */
+   */
   private int maxNumReconnectTries = DEFAULT_MAX_NUM_RECONNECT_TRIES;
 
 
@@ -200,19 +247,29 @@ public class DistributionConfigImpl
   protected int asyncQueueTimeout = DEFAULT_ASYNC_QUEUE_TIMEOUT;
   protected int asyncMaxQueueSize = DEFAULT_ASYNC_MAX_QUEUE_SIZE;
 
-  /** @since GemFire 5.7 */
+  /**
+   * @since GemFire 5.7
+   */
   private String clientConflation = CLIENT_CONFLATION_PROP_VALUE_DEFAULT;
 
-  /** The id of the durable client */
+  /**
+   * The id of the durable client
+   */
   private String durableClientId = DEFAULT_DURABLE_CLIENT_ID;
 
-  /** The timeout of the durable client */
+  /**
+   * The timeout of the durable client
+   */
   private int durableClientTimeout = DEFAULT_DURABLE_CLIENT_TIMEOUT;
 
-  /** The client authentication initialization method name*/
+  /**
+   * The client authentication initialization method name
+   */
   private String securityClientAuthInit = DEFAULT_SECURITY_CLIENT_AUTH_INIT;
 
-  /** The client authenticating method name*/
+  /**
+   * The client authenticating method name
+   */
   private String securityClientAuthenticator = DEFAULT_SECURITY_CLIENT_AUTHENTICATOR;
 
   /** The security manager class name*/
@@ -224,41 +281,60 @@ public class DistributionConfigImpl
   /** The client Diffie-Hellman method name*/
   private String securityClientDHAlgo = DEFAULT_SECURITY_CLIENT_DHALGO;
 
-  /** The peer authentication initialization method name*/
+  /**
+   * The peer authentication initialization method name
+   */
   private String securityPeerAuthInit = DEFAULT_SECURITY_PEER_AUTH_INIT;
 
-  /** The peer authenticating method name*/
+  /**
+   * The peer authenticating method name
+   */
   private String securityPeerAuthenticator = DEFAULT_SECURITY_PEER_AUTHENTICATOR;
 
-  /** The client authorization method name*/
+  /**
+   * The client authorization method name
+   */
   private String securityClientAccessor = DEFAULT_SECURITY_CLIENT_ACCESSOR;
 
-  /** The post-processing client authorization method name*/
+  /**
+   * The post-processing client authorization method name
+   */
   private String securityClientAccessorPP = DEFAULT_SECURITY_CLIENT_ACCESSOR_PP;
 
   /**
    * The level at which security related log messages are logged
-   *
    * @see com.gemstone.gemfire.internal.logging.LogWriterImpl#levelNameToCode(String)
    */
   protected int securityLogLevel = DEFAULT_LOG_LEVEL;
 
-  /** whether network partition detection algorithms are enabled */
+  /**
+   * whether network partition detection algorithms are enabled
+   */
   private boolean enableNetworkPartitionDetection = DEFAULT_ENABLE_NETWORK_PARTITION_DETECTION;
-  
-  /** whether auto reconnect after network partition is disabled */
+
+  /**
+   * whether auto reconnect after network partition is disabled
+   */
   private boolean disableAutoReconnect = DEFAULT_DISABLE_AUTO_RECONNECT;
 
-  /** The security log file */
+  /**
+   * The security log file
+   */
   private File securityLogFile = DEFAULT_SECURITY_LOG_FILE;
 
-  /** The p2p membership check timeout */
+  /**
+   * The p2p membership check timeout
+   */
   private int securityPeerMembershipTimeout = DEFAULT_SECURITY_PEER_VERIFYMEMBER_TIMEOUT;
 
-  /** The member security credentials */
+  /**
+   * The member security credentials
+   */
   private Properties security = new Properties();
 
-  /** The User defined properties to be used for cache.xml replacements */
+  /**
+   * The User defined properties to be used for cache.xml replacements
+   */
   private Properties userDefinedProps = new Properties();
   /**
    * Prefix to use for properties that are put as JVM java properties for use
@@ -267,29 +343,39 @@ public class DistributionConfigImpl
    */
   public static final String SECURITY_SYSTEM_PREFIX = GEMFIRE_PREFIX + "sys.";
 
-  /** whether to remove unresponsive client or not */
+  /**
+   * whether to remove unresponsive client or not
+   */
   private boolean removeUnresponsiveClient = DEFAULT_REMOVE_UNRESPONSIVE_CLIENT;
 
-  /** Is delta propagation enabled or not **/
+  /**
+   * Is delta propagation enabled or not
+   **/
   private boolean deltaPropagation = DEFAULT_DELTA_PROPAGATION;
-  
+
   private Map props;
-  
+
   private int distributedSystemId = DistributionConfig.DEFAULT_DISTRIBUTED_SYSTEM_ID;
 
-  /** The locations of the remote distribution locators */
+  /**
+   * The locations of the remote distribution locators
+   */
   private String remoteLocators = DEFAULT_REMOTE_LOCATORS;
-  
+
   private boolean enforceUniqueHost = DistributionConfig.DEFAULT_ENFORCE_UNIQUE_HOST;
-  
+
   private String redundancyZone = DistributionConfig.DEFAULT_REDUNDANCY_ZONE;
 
-  /** holds the ssl properties specified in gfsecurity.properties */
+  /**
+   * holds the ssl properties specified in gfsecurity.properties
+   */
   private Properties sslProperties = new Properties();
-  
-  /** holds the ssl properties specified in gfsecurity.properties */
+
+  /**
+   * holds the ssl properties specified in gfsecurity.properties
+   */
   private Properties clusterSSLProperties = new Properties();
-  
+
   private String groups = DEFAULT_GROUPS;
   
   protected boolean enableSharedConfiguration = DistributionConfig.DEFAULT_ENABLE_CLUSTER_CONFIGURATION;
@@ -301,7 +387,7 @@ public class DistributionConfigImpl
   private int httpServicePort = DEFAULT_HTTP_SERVICE_PORT;
 
   private String httpServiceBindAddress = DEFAULT_HTTP_SERVICE_BIND_ADDRESS;
-  
+
   private boolean startDevRestApi = DEFAULT_START_DEV_REST_API;
   /**
    * port on which {@link GemFireMemcachedServer} server is started
@@ -317,96 +403,109 @@ public class DistributionConfigImpl
    * Bind address for GemFireMemcachedServer
    */
   private String memcachedBindAddress = DEFAULT_MEMCACHED_BIND_ADDRESS;
-  
-  /** Are distributed transactions enabled or not */
+
+  /**
+   * Are distributed transactions enabled or not
+   */
   private boolean distributedTransactions = DEFAULT_DISTRIBUTED_TRANSACTIONS;
 
-  
+
   /**
    * port on which {@link GeodeRedisServer} is started
    */
   private int redisPort = DEFAULT_REDIS_PORT;
-  
+
   /**
    * Bind address for GeodeRedisServer
    */
   private String redisBindAddress = DEFAULT_REDIS_BIND_ADDRESS;
-  
+
   private String redisPassword = DEFAULT_REDIS_PASSWORD;
 
   private boolean jmxManager = Boolean.getBoolean(InternalLocator.FORCE_LOCATOR_DM_TYPE) ? true : DEFAULT_JMX_MANAGER;
   private boolean jmxManagerStart = DEFAULT_JMX_MANAGER_START;
-  
+
   private int jmxManagerPort = DEFAULT_JMX_MANAGER_PORT;
   private String jmxManagerBindAddress = DEFAULT_JMX_MANAGER_BIND_ADDRESS;
   private String jmxManagerHostnameForClients = DEFAULT_JMX_MANAGER_HOSTNAME_FOR_CLIENTS;
   private String jmxManagerPasswordFile = DEFAULT_JMX_MANAGER_PASSWORD_FILE;
   private String jmxManagerAccessFile = DEFAULT_JMX_MANAGER_ACCESS_FILE;
-  private int jmxManagerHttpPort = DEFAULT_HTTP_SERVICE_PORT; 
+  private int jmxManagerHttpPort = DEFAULT_HTTP_SERVICE_PORT;
   private int jmxManagerUpdateRate = DEFAULT_JMX_MANAGER_UPDATE_RATE;
- 
-  private boolean jmxManagerSSL = DEFAULT_JMX_MANAGER_SSL;
+
   private boolean jmxManagerSSLEnabled = DEFAULT_JMX_MANAGER_SSL_ENABLED;
   private boolean jmxManagerSslRequireAuthentication = DEFAULT_JMX_MANAGER_SSL_REQUIRE_AUTHENTICATION;
   private String jmxManagerSslProtocols = DEFAULT_JMX_MANAGER_SSL_PROTOCOLS;
   private String jmxManagerSslCiphers = DEFAULT_JMX_MANAGER_SSL_CIPHERS;
   private Properties jmxManagerSslProperties = new Properties();
-  
-  protected String jmxManagerSSLKeyStore = DEFAULT_JMX_MANAGER_SSL_KEYSTORE;
-  protected String jmxManagerSSLKeyStoreType = DEFAULT_JMX_MANAGER_SSL_KEYSTORE_TYPE;
-  protected String jmxManagerSSLKeyStorePassword = DEFAULT_JMX_MANAGER_SSL_KEYSTORE_PASSWORD;
-  protected String jmxManagerSSLTrustStore = DEFAULT_JMX_MANAGER_SSL_TRUSTSTORE;
-  protected String jmxManagerSSLTrustStorePassword = DEFAULT_JMX_MANAGER_SSL_TRUSTSTORE_PASSWORD;
-  
+
+  private String jmxManagerSSLKeyStore = DEFAULT_JMX_MANAGER_SSL_KEYSTORE;
+  private String jmxManagerSSLKeyStoreType = DEFAULT_JMX_MANAGER_SSL_KEYSTORE_TYPE;
+  private String jmxManagerSSLKeyStorePassword = DEFAULT_JMX_MANAGER_SSL_KEYSTORE_PASSWORD;
+  private String jmxManagerSSLTrustStore = DEFAULT_JMX_MANAGER_SSL_TRUSTSTORE;
+  private String jmxManagerSSLTrustStorePassword = DEFAULT_JMX_MANAGER_SSL_TRUSTSTORE_PASSWORD;
+
+  private String jmxManagerSSLAlias = clusterSSLAlias;
+
   private boolean serverSSLEnabled = DEFAULT_SERVER_SSL_ENABLED;
   private boolean serverSslRequireAuthentication = DEFAULT_SERVER_SSL_REQUIRE_AUTHENTICATION;
   private String serverSslProtocols = DEFAULT_SERVER_SSL_PROTOCOLS;
   private String serverSslCiphers = DEFAULT_SERVER_SSL_CIPHERS;
   private Properties serverSslProperties = new Properties();
-  
-  protected String serverSSLKeyStore = DEFAULT_SERVER_SSL_KEYSTORE;
-  protected String serverSSLKeyStoreType = DEFAULT_SERVER_SSL_KEYSTORE_TYPE;
-  protected String serverSSLKeyStorePassword = DEFAULT_SERVER_SSL_KEYSTORE_PASSWORD;
-  protected String serverSSLTrustStore = DEFAULT_SERVER_SSL_TRUSTSTORE;
-  protected String serverSSLTrustStorePassword = DEFAULT_SERVER_SSL_TRUSTSTORE_PASSWORD;
+
+  private String serverSSLKeyStore = DEFAULT_SERVER_SSL_KEYSTORE;
+  private String serverSSLKeyStoreType = DEFAULT_SERVER_SSL_KEYSTORE_TYPE;
+  private String serverSSLKeyStorePassword = DEFAULT_SERVER_SSL_KEYSTORE_PASSWORD;
+  private String serverSSLTrustStore = DEFAULT_SERVER_SSL_TRUSTSTORE;
+  private String serverSSLTrustStorePassword = DEFAULT_SERVER_SSL_TRUSTSTORE_PASSWORD;
+
+  private String serverSSLAlias = clusterSSLAlias;
 
   private boolean gatewaySSLEnabled = DEFAULT_GATEWAY_SSL_ENABLED;
   private boolean gatewaySslRequireAuthentication = DEFAULT_GATEWAY_SSL_REQUIRE_AUTHENTICATION;
   private String gatewaySslProtocols = DEFAULT_GATEWAY_SSL_PROTOCOLS;
   private String gatewaySslCiphers = DEFAULT_GATEWAY_SSL_CIPHERS;
   private Properties gatewaySslProperties = new Properties();
-  
-  protected String gatewaySSLKeyStore = DEFAULT_GATEWAY_SSL_KEYSTORE;
-  protected String gatewaySSLKeyStoreType = DEFAULT_GATEWAY_SSL_KEYSTORE_TYPE;
-  protected String gatewaySSLKeyStorePassword = DEFAULT_GATEWAY_SSL_KEYSTORE_PASSWORD;
-  protected String gatewaySSLTrustStore = DEFAULT_GATEWAY_SSL_TRUSTSTORE;
-  protected String gatewaySSLTrustStorePassword = DEFAULT_GATEWAY_SSL_TRUSTSTORE_PASSWORD;
-  
-  
+
+  private String gatewaySSLKeyStore = DEFAULT_GATEWAY_SSL_KEYSTORE;
+  private String gatewaySSLKeyStoreType = DEFAULT_GATEWAY_SSL_KEYSTORE_TYPE;
+  private String gatewaySSLKeyStorePassword = DEFAULT_GATEWAY_SSL_KEYSTORE_PASSWORD;
+  private String gatewaySSLTrustStore = DEFAULT_GATEWAY_SSL_TRUSTSTORE;
+  private String gatewaySSLTrustStorePassword = DEFAULT_GATEWAY_SSL_TRUSTSTORE_PASSWORD;
+
+  private String gatewaySSLAlias = clusterSSLAlias;
+
+
   private boolean httpServiceSSLEnabled = DEFAULT_HTTP_SERVICE_SSL_ENABLED;
   private boolean httpServiceSSLRequireAuthentication = DEFAULT_HTTP_SERVICE_SSL_REQUIRE_AUTHENTICATION;
   private String httpServiceSSLProtocols = DEFAULT_HTTP_SERVICE_SSL_PROTOCOLS;
   private String httpServiceSSLCiphers = DEFAULT_HTTP_SERVICE_SSL_CIPHERS;
   private Properties httpServiceSSLProperties = new Properties();
-  
-  protected String httpServiceSSLKeyStore = DEFAULT_HTTP_SERVICE_SSL_KEYSTORE;
-  protected String httpServiceSSLKeyStoreType = DEFAULT_HTTP_SERVICE_SSL_KEYSTORE_TYPE;
-  protected String httpServiceSSLKeyStorePassword = DEFAULT_HTTP_SERVICE_SSL_KEYSTORE_PASSWORD;
-  protected String httpServiceSSLTrustStore = DEFAULT_HTTP_SERVICE_SSL_TRUSTSTORE;
-  protected String httpServiceSSLTrustStorePassword = DEFAULT_HTTP_SERVICE_SSL_TRUSTSTORE_PASSWORD;
-  
+
+  private String httpServiceSSLKeyStore = DEFAULT_HTTP_SERVICE_SSL_KEYSTORE;
+  private String httpServiceSSLKeyStoreType = DEFAULT_HTTP_SERVICE_SSL_KEYSTORE_TYPE;
+  private String httpServiceSSLKeyStorePassword = DEFAULT_HTTP_SERVICE_SSL_KEYSTORE_PASSWORD;
+  private String httpServiceSSLTrustStore = DEFAULT_HTTP_SERVICE_SSL_TRUSTSTORE;
+  private String httpServiceSSLTrustStorePassword = DEFAULT_HTTP_SERVICE_SSL_TRUSTSTORE_PASSWORD;
+
+  private String httpServiceSSLAlias = clusterSSLAlias;
+
   private Map<String, ConfigSource> sourceMap = Collections.synchronizedMap(new HashMap<String, ConfigSource>());
-  
+
   protected String userCommandPackages = DEFAULT_USER_COMMAND_PACKAGES;
-  
-  /** "off-heap-memory-size" with value of "" or "<size>[g|m]" */
+
+  /**
+   * "off-heap-memory-size" with value of "" or "<size>[g|m]"
+   */
   protected String offHeapMemorySize = DEFAULT_OFF_HEAP_MEMORY_SIZE;
-  
-  /** Whether pages should be locked into memory or allowed to swap to disk */
+
+  /**
+   * Whether pages should be locked into memory or allowed to swap to disk
+   */
   private boolean lockMemory = DEFAULT_LOCK_MEMORY;
 
   private String shiroInit = "";
-  
+
   //////////////////////  Constructors  //////////////////////
 
   /**
@@ -425,11 +524,11 @@ public class DistributionConfigImpl
     this.mcastAddress = other.getMcastAddress();
     this.bindAddress = other.getBindAddress();
     this.serverBindAddress = other.getServerBindAddress();
-    this.locators = ((DistributionConfigImpl)other).locators; 
+    this.locators = ((DistributionConfigImpl) other).locators;
     this.locatorWaitTime = other.getLocatorWaitTime();
     this.remoteLocators = other.getRemoteLocators();
     this.startLocator = other.getStartLocator();
-    this.startLocatorPort = ((DistributionConfigImpl)other).startLocatorPort;
+    this.startLocatorPort = ((DistributionConfigImpl) other).startLocatorPort;
     this.deployWorkingDir = other.getDeployWorkingDir();
     this.logFile = other.getLogFile();
     this.logLevel = other.getLogLevel();
@@ -443,19 +542,15 @@ public class DistributionConfigImpl
     this.archiveFileSizeLimit = other.getArchiveFileSizeLimit();
     this.logDiskSpaceLimit = other.getLogDiskSpaceLimit();
     this.logFileSizeLimit = other.getLogFileSizeLimit();
-    this.sslEnabled = other.getSSLEnabled();
-    this.sslProtocols = other.getSSLProtocols();
-    this.sslCiphers = other.getSSLCiphers();
-    this.sslRequireAuthentication = other.getSSLRequireAuthentication();
     this.clusterSSLEnabled = other.getClusterSSLEnabled();
     this.clusterSSLProtocols = other.getClusterSSLProtocols();
     this.clusterSSLCiphers = other.getClusterSSLCiphers();
     this.clusterSSLRequireAuthentication = other.getClusterSSLRequireAuthentication();
     this.clusterSSLKeyStore = other.getClusterSSLKeyStore();
-    this.clusterSSLKeyStoreType= other.getClusterSSLKeyStoreType();
-    this.clusterSSLKeyStorePassword= other.getClusterSSLKeyStorePassword();
-    this.clusterSSLTrustStore= other.getClusterSSLTrustStore();
-    this.clusterSSLTrustStorePassword= other.getClusterSSLTrustStorePassword();
+    this.clusterSSLKeyStoreType = other.getClusterSSLKeyStoreType();
+    this.clusterSSLKeyStorePassword = other.getClusterSSLKeyStorePassword();
+    this.clusterSSLTrustStore = other.getClusterSSLTrustStore();
+    this.clusterSSLTrustStorePassword = other.getClusterSSLTrustStorePassword();
     this.asyncDistributionTimeout = other.getAsyncDistributionTimeout();
     this.asyncQueueTimeout = other.getAsyncQueueTimeout();
     this.asyncMaxQueueSize = other.getAsyncMaxQueueSize();
@@ -501,21 +596,20 @@ public class DistributionConfigImpl
     this.jmxManagerSslProperties = other.getJmxSSLProperties();
     //Similar to this.security, assigning userDefinedProps
     this.userDefinedProps.putAll(other.getUserDefinedProps());
-    
+
     // following added for 7.0
     this.groups = other.getGroups();
     this.jmxManager = other.getJmxManager();
     this.jmxManagerStart = other.getJmxManagerStart();
-    this.jmxManagerSSL = other.getJmxManagerSSL();
     this.jmxManagerSSLEnabled = other.getJmxManagerSSLEnabled();
     this.jmxManagerSslRequireAuthentication = other.getJmxManagerSSLRequireAuthentication();
     this.jmxManagerSslProtocols = other.getJmxManagerSSLProtocols();
     this.jmxManagerSslCiphers = other.getJmxManagerSSLCiphers();
     this.jmxManagerSSLKeyStore = other.getJmxManagerSSLKeyStore();
-    this.jmxManagerSSLKeyStoreType= other.getJmxManagerSSLKeyStoreType();
-    this.jmxManagerSSLKeyStorePassword= other.getJmxManagerSSLKeyStorePassword();
-    this.jmxManagerSSLTrustStore= other.getJmxManagerSSLTrustStore();
-    this.jmxManagerSSLTrustStorePassword= other.getJmxManagerSSLTrustStorePassword();
+    this.jmxManagerSSLKeyStoreType = other.getJmxManagerSSLKeyStoreType();
+    this.jmxManagerSSLKeyStorePassword = other.getJmxManagerSSLKeyStorePassword();
+    this.jmxManagerSSLTrustStore = other.getJmxManagerSSLTrustStore();
+    this.jmxManagerSSLTrustStorePassword = other.getJmxManagerSSLTrustStorePassword();
     this.jmxManagerSslProperties = other.getJmxSSLProperties();
     this.jmxManagerPort = other.getJmxManagerPort();
     this.jmxManagerBindAddress = other.getJmxManagerBindAddress();
@@ -531,7 +625,7 @@ public class DistributionConfigImpl
     this.redisBindAddress = other.getRedisBindAddress();
     this.redisPassword = other.getRedisPassword();
     this.userCommandPackages = other.getUserCommandPackages();
-    
+
     // following added for 8.0
     this.enableSharedConfiguration = other.getEnableClusterConfiguration();
     this.loadSharedConfigurationFromDir = other.getLoadClusterConfigFromDir();
@@ -542,26 +636,26 @@ public class DistributionConfigImpl
     this.serverSslProtocols = other.getServerSSLProtocols();
     this.serverSslCiphers = other.getServerSSLCiphers();
     this.serverSSLKeyStore = other.getServerSSLKeyStore();
-    this.serverSSLKeyStoreType= other.getServerSSLKeyStoreType();
-    this.serverSSLKeyStorePassword= other.getServerSSLKeyStorePassword();
-    this.serverSSLTrustStore= other.getServerSSLTrustStore();
-    this.serverSSLTrustStorePassword= other.getServerSSLTrustStorePassword();
+    this.serverSSLKeyStoreType = other.getServerSSLKeyStoreType();
+    this.serverSSLKeyStorePassword = other.getServerSSLKeyStorePassword();
+    this.serverSSLTrustStore = other.getServerSSLTrustStore();
+    this.serverSSLTrustStorePassword = other.getServerSSLTrustStorePassword();
     this.serverSslProperties = other.getServerSSLProperties();
-    
+
     this.gatewaySSLEnabled = other.getGatewaySSLEnabled();
     this.gatewaySslRequireAuthentication = other.getGatewaySSLRequireAuthentication();
     this.gatewaySslProtocols = other.getGatewaySSLProtocols();
     this.gatewaySslCiphers = other.getGatewaySSLCiphers();
     this.gatewaySSLKeyStore = other.getGatewaySSLKeyStore();
-    this.gatewaySSLKeyStoreType= other.getGatewaySSLKeyStoreType();
-    this.gatewaySSLKeyStorePassword= other.getGatewaySSLKeyStorePassword();
-    this.gatewaySSLTrustStore= other.getGatewaySSLTrustStore();
-    this.gatewaySSLTrustStorePassword= other.getGatewaySSLTrustStorePassword();
+    this.gatewaySSLKeyStoreType = other.getGatewaySSLKeyStoreType();
+    this.gatewaySSLKeyStorePassword = other.getGatewaySSLKeyStorePassword();
+    this.gatewaySSLTrustStore = other.getGatewaySSLTrustStore();
+    this.gatewaySSLTrustStorePassword = other.getGatewaySSLTrustStorePassword();
     this.gatewaySslProperties = other.getGatewaySSLProperties();
-    
+
     this.httpServicePort = other.getHttpServicePort();
     this.httpServiceBindAddress = other.getHttpServiceBindAddress();
-    
+
     this.httpServiceSSLEnabled = other.getHttpServiceSSLEnabled();
     this.httpServiceSSLCiphers = other.getHttpServiceSSLCiphers();
     this.httpServiceSSLProtocols = other.getHttpServiceSSLProtocols();
@@ -572,22 +666,27 @@ public class DistributionConfigImpl
     this.httpServiceSSLTrustStore = other.getHttpServiceSSLTrustStore();
     this.httpServiceSSLTrustStorePassword = other.getHttpServiceSSLTrustStorePassword();
     this.httpServiceSSLProperties = other.getHttpServiceSSLProperties();
-    
+
     this.startDevRestApi = other.getStartDevRestApi();
 
     // following added for 9.0
     this.offHeapMemorySize = other.getOffHeapMemorySize();
-    
-    Map<String, ConfigSource> otherSources = ((DistributionConfigImpl)other).sourceMap;
+
+    Map<String, ConfigSource> otherSources = ((DistributionConfigImpl) other).sourceMap;
     if (otherSources != null) {
       this.sourceMap = new HashMap<String, ConfigSource>(otherSources);
     }
-    
+
     this.lockMemory = other.getLockMemory();
     this.distributedTransactions = other.getDistributedTransactions();
     this.shiroInit = other.getShiroInit();
     this.securityManager = other.getSecurityManager();
     this.postProcessor = other.getPostProcessor();
+    this.clusterSSLAlias = other.getClusterSSLAlias();
+    this.gatewaySSLAlias = other.getGatewaySSLAlias();
+    this.httpServiceSSLAlias = other.getHTTPServiceSSLAlias();
+    this.jmxManagerSSLAlias = other.getJMXManagerSSLAlias();
+    this.serverSSLAlias = other.getServerSSLAlias();
   }
 
   /**
@@ -615,9 +714,7 @@ public class DistributionConfigImpl
    * non-default configuration properties.  See {@link
    * com.gemstone.gemfire.distributed.DistributedSystem#connect} for a
    * list of exceptions that may be thrown.
-   *
-   * @param nonDefault
-   *        The configuration properties specified by the caller
+   * @param nonDefault The configuration properties specified by the caller
    */
   public DistributionConfigImpl(Properties nonDefault) {
     this(nonDefault, false, false);
@@ -628,41 +725,32 @@ public class DistributionConfigImpl
    * non-default configuration properties. See
    * {@link com.gemstone.gemfire.distributed.DistributedSystem#connect} for a
    * list of exceptions that may be thrown.
-   * 
-   * @param nonDefault
-   *          The configuration properties specified by the caller
-   * @param ignoreGemFirePropsFile
-   *          whether to skip loading distributed system properties from
-   *          gemfire.properties file
-   *          
+   * @param nonDefault The configuration properties specified by the caller
+   * @param ignoreGemFirePropsFile whether to skip loading distributed system properties from
+   * gemfire.properties file
+   *
    * @since GemFire 6.5
    */
-  
-  public DistributionConfigImpl(Properties nonDefault, 
-      boolean ignoreGemFirePropsFile) {
+
+  public DistributionConfigImpl(Properties nonDefault, boolean ignoreGemFirePropsFile) {
     this(nonDefault, ignoreGemFirePropsFile, false);
   }
-  
+
   /**
    * Creates a new <code>DistributionConfigImpl</code> with the given
    * non-default configuration properties. See
    * {@link com.gemstone.gemfire.distributed.DistributedSystem#connect} for a
    * list of exceptions that may be thrown.
-   * 
-   * @param nonDefault
-   *          The configuration properties specified by the caller
-   * @param ignoreGemFirePropsFile
-   *          whether to skip loading distributed system properties from
-   *          gemfire.properties file
-   * @param isConnected
-   *          whether to skip Validation for SSL properties and copy of ssl
-   *          properties to other ssl properties. This parameter will be used
-   *          till we provide support for ssl-* properties.
-   * 
+   * @param nonDefault The configuration properties specified by the caller
+   * @param ignoreGemFirePropsFile whether to skip loading distributed system properties from
+   * gemfire.properties file
+   * @param isConnected whether to skip Validation for SSL properties and copy of ssl
+   * properties to other ssl properties. This parameter will be used
+   * till we provide support for ssl-* properties.
+   *
    * @since GemFire 8.0
    */
-  public DistributionConfigImpl(Properties nonDefault, 
-                                boolean ignoreGemFirePropsFile, boolean isConnected) {
+  public DistributionConfigImpl(Properties nonDefault, boolean ignoreGemFirePropsFile, boolean isConnected) {
     HashMap props = new HashMap();
     if (!ignoreGemFirePropsFile) {//For admin bug #40434
       props.putAll(loadPropertiesFromURL(DistributedSystem.getPropertyFileURL(), false));
@@ -677,8 +765,8 @@ public class DistributionConfigImpl
     }
     //Now remove all user defined properties from props.
     for (Object entry : props.entrySet()) {
-      Map.Entry<String, String> ent = (Map.Entry<String, String>)entry; 
-      if (((String)ent.getKey()).startsWith(USERDEFINED_PREFIX_NAME)){
+      Map.Entry<String, String> ent = (Map.Entry<String, String>) entry;
+      if (((String) ent.getKey()).startsWith(USERDEFINED_PREFIX_NAME)) {
         userDefinedProps.put(ent.getKey(), ent.getValue());
       }
     }
@@ -697,12 +785,10 @@ public class DistributionConfigImpl
     Properties sysProps = (Properties) System.getProperties().clone();
     Iterator<?> sysPropsIter = sysProps.entrySet().iterator();
     while (sysPropsIter.hasNext()) {
-      Map.Entry sysEntry = (Map.Entry)sysPropsIter.next();
-      String sysName = (String)sysEntry.getKey();
-      if (attNameSet.contains(sysName)
-          || sysName.startsWith(GEMFIRE_PREFIX + SECURITY_PREFIX_NAME)
-          || sysName.startsWith(GEMFIRE_PREFIX + SSL_SYSTEM_PROPS_NAME)) {
-        String sysValue = (String)sysEntry.getValue();
+      Map.Entry sysEntry = (Map.Entry) sysPropsIter.next();
+      String sysName = (String) sysEntry.getKey();
+      if (attNameSet.contains(sysName) || sysName.startsWith(GEMFIRE_PREFIX + SECURITY_PREFIX_NAME) || sysName.startsWith(GEMFIRE_PREFIX + SSL_SYSTEM_PROPS_NAME)) {
+        String sysValue = (String) sysEntry.getValue();
         if (sysValue != null) {
           String attName = sysName.substring(GEMFIRE_PREFIX.length());
           props.put(attName, sysValue);
@@ -711,7 +797,7 @@ public class DistributionConfigImpl
       }
     }
     sysProps.clear(); //clearing cloned SysProps
-    
+
     final Properties overriddenDefaults = ProcessLauncherContext.getOverriddenDefaults();
     if (!overriddenDefaults.isEmpty()) {
       for (String key : overriddenDefaults.stringPropertyNames()) {
@@ -723,205 +809,104 @@ public class DistributionConfigImpl
         }
       }
     }
-    
-    // this is case of locator and DS is started through
-    // Locator.startLocatorAndDS, In this case I don't need to validate SSL
-    // properties. This fix is till the time we support SSL properties. Once SSl
-    // properties is depprecated, boolean isConnected will be removed
-    if (!isConnected) {
-      validateOldSSLVsNewSSLProperties(props);
-    }
+
     initialize(props);
 
     if (securityPeerAuthInit != null && securityPeerAuthInit.length() > 0) {
-      System.setProperty(SECURITY_SYSTEM_PREFIX + SECURITY_PEER_AUTH_INIT,
-          securityPeerAuthInit);
+      System.setProperty(SECURITY_SYSTEM_PREFIX + SECURITY_PEER_AUTH_INIT, securityPeerAuthInit);
     }
-    if (securityPeerAuthenticator != null
-        && securityPeerAuthenticator.length() > 0) {
-      System.setProperty(SECURITY_SYSTEM_PREFIX
-          + SECURITY_PEER_AUTHENTICATOR, securityPeerAuthenticator);
+    if (securityPeerAuthenticator != null && securityPeerAuthenticator.length() > 0) {
+      System.setProperty(SECURITY_SYSTEM_PREFIX + SECURITY_PEER_AUTHENTICATOR, securityPeerAuthenticator);
     }
 
     Iterator iter = security.entrySet().iterator();
     while (iter.hasNext()) {
-      Map.Entry entry = (Map.Entry)iter.next();
-      System.setProperty(SECURITY_SYSTEM_PREFIX + (String)entry.getKey(),
-          (String)entry.getValue());
+      Map.Entry entry = (Map.Entry) iter.next();
+      System.setProperty(SECURITY_SYSTEM_PREFIX + (String) entry.getKey(), (String) entry.getValue());
     }
     computeMcastPortDefault();
     if (!isConnected) {
-      copySSLPropsToClusterSSLProps();
       copySSLPropsToServerSSLProps();
       copySSLPropsToJMXSSLProps();
       copyClusterSSLPropsToGatewaySSLProps();
       copySSLPropsToHTTPSSLProps();
     }
   }
-  
-  private void validateOldSSLVsNewSSLProperties(Map props) {
-    String sslEnabledString = (String)props.get(SSL_ENABLED);
-    String clusterSSLEnabledString =(String)props.get(CLUSTER_SSL_ENABLED);
-    if(sslEnabledString != null && clusterSSLEnabledString != null){
-      boolean sslEnabled = new Boolean(sslEnabledString).booleanValue();
-      boolean clusterSSLEnabled =new Boolean(clusterSSLEnabledString).booleanValue();
-      if (sslEnabled != clusterSSLEnabled) {
-        throw new IllegalArgumentException(
-            "GemFire properties \'ssl-enabled\' and \'cluster-ssl-enabled\' can not be used at the same time and have different values. The preferred way is to use all \'cluster-ssl*\' properties instead of \'ssl-*\'.");
-      }
-    }
-    
-    String sslCipher = (String)props.get(SSL_CIPHERS);
-    String clusterSSLCipher = (String)props.get(CLUSTER_SSL_CIPHERS);
-    if (sslCipher != null && clusterSSLCipher != null) {
-      if ( !sslCipher.equals(clusterSSLCipher) ) {
-        throw new IllegalArgumentException(
-          "GemFire properties \'ssl-cipher\' and \'cluster-ssl-cipher\' can not be used at the same time and have different values. The preferred way is to use all \'cluster-ssl*\' properties instead of \'ssl-*\'.");
-      }
-    }
-
-    String sslProtocol = (String)props.get(SSL_PROTOCOLS);
-    String clusterSSLProtocol = (String)props.get(CLUSTER_SSL_PROTOCOLS);
-    if (sslProtocol != null && clusterSSLProtocol != null) {
-      if ( !sslProtocol.equals(clusterSSLProtocol) ) {
-        throw new IllegalArgumentException(
-          "GemFire properties \'ssl-protocols\' and \'cluster-ssl-protocols\' can not be used at the same time and have different values. The preferred way is to use all \'cluster-ssl*\' properties instead of \'ssl-*\'.");
-      }
-    }
-    
-    String sslReqAuthString = (String)props.get(SSL_REQUIRE_AUTHENTICATION);
-    String clusterReqAuthString =(String)props.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION);
-    if(sslReqAuthString != null && clusterReqAuthString != null){
-      boolean sslReqAuth = new Boolean(sslReqAuthString).booleanValue();
-      boolean clusterSSLReqAuth =new Boolean(clusterReqAuthString).booleanValue();
-      if (sslReqAuth != clusterSSLReqAuth) {
-        throw new IllegalArgumentException(
-            "GemFire properties \'ssl-require-authentication\' and \'cluster-ssl-require-authentication\' can not be used at the same time and have different values. The preferred way is to use all \'cluster-ssl*\' properties instead of \'ssl-*\'.");
-      }
-    }
-    
-    String jmxSSLString = (String)props.get(JMX_MANAGER_SSL);
-    String jmxSSLEnabledString =(String)props.get(JMX_MANAGER_SSL_ENABLED);
-    if(jmxSSLString != null && jmxSSLEnabledString != null){
-      boolean jmxSSL = new Boolean(jmxSSLString).booleanValue();
-      boolean jmxSSLEnabled =new Boolean(jmxSSLEnabledString).booleanValue();
-      if (jmxSSL != jmxSSLEnabled) {
-        throw new IllegalArgumentException(
-            "GemFire properties \'jmx-manager-ssl\' and \'jmx-manager-ssl-enabled\' can not be used at the same time and have different values and have different values. The preferred way is to use \'jmx-manager-ssl-enabled\' instead of \'jmx-manager-ssl\'.");
-      }
-    }
-  }
-  
-  /*
-   * ssl-* properties will be copied in cluster-ssl-* properties. Socket is using cluster-ssl-* properties
-   */
-  private void copySSLPropsToClusterSSLProps() {
-    boolean clusterSSLOverriden = this.sourceMap.get(CLUSTER_SSL_ENABLED)!=null;
-    boolean p2pSSLOverRidden = this.sourceMap.get(SSL_ENABLED)!=null;
-    
-    if(p2pSSLOverRidden && !clusterSSLOverriden) {
-      this.clusterSSLEnabled  = this.sslEnabled;
-      this.sourceMap.put(CLUSTER_SSL_ENABLED,this.sourceMap.get(SSL_ENABLED));
-      
-      if(this.sourceMap.get(SSL_CIPHERS)!=null) {
-        this.clusterSSLCiphers = this.sslCiphers;
-        this.sourceMap.put(CLUSTER_SSL_CIPHERS,this.sourceMap.get(SSL_CIPHERS));
-      }
-      
-      if(this.sourceMap.get(SSL_PROTOCOLS)!=null) {
-        this.clusterSSLProtocols = this.sslProtocols;
-        this.sourceMap.put(CLUSTER_SSL_PROTOCOLS,this.sourceMap.get(SSL_PROTOCOLS));
-      }
-      
-      if(this.sourceMap.get(SSL_REQUIRE_AUTHENTICATION)!=null) {
-        this.clusterSSLRequireAuthentication = this.sslRequireAuthentication;
-        this.sourceMap.put(CLUSTER_SSL_REQUIRE_AUTHENTICATION,this.sourceMap.get(SSL_REQUIRE_AUTHENTICATION));
-      }      
-      this.clusterSSLProperties.putAll(this.sslProperties);
-    }  
-  }
-  
+
   /*
    * if jmx-manager-ssl is true and jmx-manager-ssl-enabled is false then override jmx-manager-ssl-enabled with jmx-manager-ssl
    * if jmx-manager-ssl-enabled is false, then use the properties from cluster-ssl-* properties
    * if jmx-manager-ssl-*properties are given then use them, and copy the unspecified jmx-manager properties from cluster-properties 
    */
   private void copySSLPropsToJMXSSLProps() {
-    boolean jmxSSLEnabledOverriden = this.sourceMap.get(JMX_MANAGER_SSL_ENABLED)!=null;
-    boolean jmxSSLOverriden = this.sourceMap.get(JMX_MANAGER_SSL)!=null;
-    boolean clusterSSLOverRidden = this.sourceMap.get(CLUSTER_SSL_ENABLED)!=null;
-    
-    if(jmxSSLOverriden && !jmxSSLEnabledOverriden) {
-      this.jmxManagerSSLEnabled  = this.jmxManagerSSL;
-      this.sourceMap.put(JMX_MANAGER_SSL_ENABLED,this.sourceMap.get(JMX_MANAGER_SSL));
-    }
-    
-    if(clusterSSLOverRidden && !jmxSSLOverriden && !jmxSSLEnabledOverriden) {
-      this.jmxManagerSSLEnabled  = this.clusterSSLEnabled;
-      this.sourceMap.put(JMX_MANAGER_SSL_ENABLED,this.sourceMap.get(CLUSTER_SSL_ENABLED));
-      if(this.sourceMap.get(CLUSTER_SSL_CIPHERS)!=null) {
+    boolean jmxSSLEnabledOverriden = this.sourceMap.get(JMX_MANAGER_SSL_ENABLED) != null;
+    boolean clusterSSLOverRidden = this.sourceMap.get(CLUSTER_SSL_ENABLED) != null;
+
+    if (clusterSSLOverRidden && !jmxSSLEnabledOverriden) {
+      this.jmxManagerSSLEnabled = this.clusterSSLEnabled;
+      this.sourceMap.put(JMX_MANAGER_SSL_ENABLED, this.sourceMap.get(CLUSTER_SSL_ENABLED));
+      if (this.sourceMap.get(CLUSTER_SSL_CIPHERS) != null) {
         this.jmxManagerSslCiphers = this.clusterSSLCiphers;
-        this.sourceMap.put(JMX_MANAGER_SSL_CIPHERS,this.sourceMap.get(CLUSTER_SSL_CIPHERS));
+        this.sourceMap.put(JMX_MANAGER_SSL_CIPHERS, this.sourceMap.get(CLUSTER_SSL_CIPHERS));
       }
-      
-      if(this.sourceMap.get(CLUSTER_SSL_PROTOCOLS)!=null) {
+
+      if (this.sourceMap.get(CLUSTER_SSL_PROTOCOLS) != null) {
         this.jmxManagerSslProtocols = this.clusterSSLProtocols;
-        this.sourceMap.put(JMX_MANAGER_SSL_PROTOCOLS,this.sourceMap.get(CLUSTER_SSL_PROTOCOLS));
+        this.sourceMap.put(JMX_MANAGER_SSL_PROTOCOLS, this.sourceMap.get(CLUSTER_SSL_PROTOCOLS));
       }
-      
-      if(this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION)!=null) {
+
+      if (this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION) != null) {
         this.jmxManagerSslRequireAuthentication = this.clusterSSLRequireAuthentication;
-        this.sourceMap.put(JMX_MANAGER_SSL_REQUIRE_AUTHENTICATION,this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION));
-      }      
+        this.sourceMap.put(JMX_MANAGER_SSL_REQUIRE_AUTHENTICATION, this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION));
+      }
 
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
         this.jmxManagerSSLKeyStore = this.clusterSSLKeyStore;
-        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
+        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
         this.jmxManagerSSLKeyStoreType = this.clusterSSLKeyStoreType;
-        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE_TYPE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
+        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE_TYPE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
         this.jmxManagerSSLKeyStorePassword = this.clusterSSLKeyStorePassword;
-        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
+        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE)!=null) {
-        this.jmxManagerSSLTrustStore= this.clusterSSLTrustStore;
-        this.sourceMap.put(JMX_MANAGER_SSL_TRUSTSTORE,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
+      if (this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
+        this.jmxManagerSSLTrustStore = this.clusterSSLTrustStore;
+        this.sourceMap.put(JMX_MANAGER_SSL_TRUSTSTORE, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD)!=null) {
-        this.jmxManagerSSLTrustStorePassword= this.clusterSSLTrustStorePassword;
-        this.sourceMap.put(JMX_MANAGER_SSL_TRUSTSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
+      if (this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
+        this.jmxManagerSSLTrustStorePassword = this.clusterSSLTrustStorePassword;
+        this.sourceMap.put(JMX_MANAGER_SSL_TRUSTSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
       }
       this.jmxManagerSslProperties.putAll(this.clusterSSLProperties);
-    }   
-    
-    if(jmxSSLOverriden || jmxSSLEnabledOverriden){
-      if(this.sourceMap.get(JMX_MANAGER_SSL_KEYSTORE)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
+    }
+
+    if (jmxSSLEnabledOverriden) {
+      if (this.sourceMap.get(JMX_MANAGER_SSL_KEYSTORE) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
         this.jmxManagerSSLKeyStore = this.clusterSSLKeyStore;
-        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
+        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
       }
-      if(this.sourceMap.get(JMX_MANAGER_SSL_KEYSTORE_TYPE)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
+      if (this.sourceMap.get(JMX_MANAGER_SSL_KEYSTORE_TYPE) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
         this.jmxManagerSSLKeyStoreType = this.clusterSSLKeyStoreType;
-        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE_TYPE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
+        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE_TYPE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
       }
-      if(this.sourceMap.get(JMX_MANAGER_SSL_KEYSTORE_PASSWORD)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
+      if (this.sourceMap.get(JMX_MANAGER_SSL_KEYSTORE_PASSWORD) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
         this.jmxManagerSSLKeyStorePassword = this.clusterSSLKeyStorePassword;
-        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
+        this.sourceMap.put(JMX_MANAGER_SSL_KEYSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
       }
-      if(this.sourceMap.get(JMX_MANAGER_SSL_TRUSTSTORE)==null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
-        this.jmxManagerSSLTrustStore= this.clusterSSLTrustStore;
-        this.sourceMap.put(JMX_MANAGER_SSL_TRUSTSTORE,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
+      if (this.sourceMap.get(JMX_MANAGER_SSL_TRUSTSTORE) == null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
+        this.jmxManagerSSLTrustStore = this.clusterSSLTrustStore;
+        this.sourceMap.put(JMX_MANAGER_SSL_TRUSTSTORE, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
       }
-      if(this.sourceMap.get(JMX_MANAGER_SSL_TRUSTSTORE_PASSWORD)==null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
-        this.jmxManagerSSLTrustStorePassword= this.clusterSSLTrustStorePassword;
-        this.sourceMap.put(JMX_MANAGER_SSL_TRUSTSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
+      if (this.sourceMap.get(JMX_MANAGER_SSL_TRUSTSTORE_PASSWORD) == null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
+        this.jmxManagerSSLTrustStorePassword = this.clusterSSLTrustStorePassword;
+        this.sourceMap.put(JMX_MANAGER_SSL_TRUSTSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
       }
     }
-  
   }
-  
+
   /*
    * if http-service-ssl-enabled is false, then use the properties from cluster-ssl-* properties
    * if http-service-ssl-*properties are given then use them, and copy the unspecified http-service properties from cluster-properties 
@@ -947,8 +932,7 @@ public class DistributionConfigImpl
 
       if (this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION) != null) {
         this.httpServiceSSLRequireAuthentication = this.clusterSSLRequireAuthentication;
-        this.sourceMap.put(HTTP_SERVICE_SSL_REQUIRE_AUTHENTICATION,
-            this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION));
+        this.sourceMap.put(HTTP_SERVICE_SSL_REQUIRE_AUTHENTICATION, this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION));
       }
 
       if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
@@ -961,8 +945,7 @@ public class DistributionConfigImpl
       }
       if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
         this.httpServiceSSLKeyStorePassword = this.clusterSSLKeyStorePassword;
-        this.sourceMap.put(HTTP_SERVICE_SSL_KEYSTORE_PASSWORD,
-            this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
+        this.sourceMap.put(HTTP_SERVICE_SSL_KEYSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
       }
       if (this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
         this.httpServiceSSLTrustStore = this.clusterSSLTrustStore;
@@ -970,42 +953,34 @@ public class DistributionConfigImpl
       }
       if (this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
         this.httpServiceSSLTrustStorePassword = this.clusterSSLTrustStorePassword;
-        this.sourceMap.put(HTTP_SERVICE_SSL_TRUSTSTORE_PASSWORD,
-            this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
+        this.sourceMap.put(HTTP_SERVICE_SSL_TRUSTSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
       }
       this.httpServiceSSLProperties.putAll(this.clusterSSLProperties);
     }
 
     if (httpServiceSSLEnabledOverriden) {
-      if (this.sourceMap.get(HTTP_SERVICE_SSL_KEYSTORE) == null
-          && this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
+      if (this.sourceMap.get(HTTP_SERVICE_SSL_KEYSTORE) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
         this.httpServiceSSLKeyStore = this.clusterSSLKeyStore;
         this.sourceMap.put(HTTP_SERVICE_SSL_KEYSTORE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
       }
-      if (this.sourceMap.get(HTTP_SERVICE_SSL_KEYSTORE_TYPE) == null
-          && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
+      if (this.sourceMap.get(HTTP_SERVICE_SSL_KEYSTORE_TYPE) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
         this.httpServiceSSLKeyStoreType = this.clusterSSLKeyStoreType;
         this.sourceMap.put(HTTP_SERVICE_SSL_KEYSTORE_TYPE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
       }
-      if (this.sourceMap.get(HTTP_SERVICE_SSL_KEYSTORE_PASSWORD) == null
-          && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
+      if (this.sourceMap.get(HTTP_SERVICE_SSL_KEYSTORE_PASSWORD) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
         this.httpServiceSSLKeyStorePassword = this.clusterSSLKeyStorePassword;
-        this.sourceMap.put(HTTP_SERVICE_SSL_KEYSTORE_PASSWORD,
-            this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
+        this.sourceMap.put(HTTP_SERVICE_SSL_KEYSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
       }
-      if (this.sourceMap.get(HTTP_SERVICE_SSL_TRUSTSTORE) == null
-          && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
+      if (this.sourceMap.get(HTTP_SERVICE_SSL_TRUSTSTORE) == null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
         this.httpServiceSSLTrustStore = this.clusterSSLTrustStore;
         this.sourceMap.put(HTTP_SERVICE_SSL_TRUSTSTORE, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
       }
-      if (this.sourceMap.get(HTTP_SERVICE_SSL_TRUSTSTORE_PASSWORD) == null
-          && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
+      if (this.sourceMap.get(HTTP_SERVICE_SSL_TRUSTSTORE_PASSWORD) == null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
         this.httpServiceSSLTrustStorePassword = this.clusterSSLTrustStorePassword;
-        this.sourceMap.put(HTTP_SERVICE_SSL_TRUSTSTORE_PASSWORD,
-            this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
+        this.sourceMap.put(HTTP_SERVICE_SSL_TRUSTSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
       }
     }
-  
+
   }
 
   /*
@@ -1013,70 +988,70 @@ public class DistributionConfigImpl
    * if server-ssl-*properties are given then use them, and copy the unspecified server properties from cluster-properties 
    */
   private void copySSLPropsToServerSSLProps() {
-    boolean cacheServerSSLOverriden = this.sourceMap.get(SERVER_SSL_ENABLED)!=null;
-    boolean clusterSSLOverRidden = this.sourceMap.get(CLUSTER_SSL_ENABLED)!=null;
-    
-    if(clusterSSLOverRidden && !cacheServerSSLOverriden) {
-      this.serverSSLEnabled  = this.clusterSSLEnabled;
-      this.sourceMap.put(SERVER_SSL_ENABLED,this.sourceMap.get(CLUSTER_SSL_ENABLED));
-      if(this.sourceMap.get(CLUSTER_SSL_CIPHERS)!=null) {
+    boolean cacheServerSSLOverriden = this.sourceMap.get(SERVER_SSL_ENABLED) != null;
+    boolean clusterSSLOverRidden = this.sourceMap.get(CLUSTER_SSL_ENABLED) != null;
+
+    if (clusterSSLOverRidden && !cacheServerSSLOverriden) {
+      this.serverSSLEnabled = this.clusterSSLEnabled;
+      this.sourceMap.put(SERVER_SSL_ENABLED, this.sourceMap.get(CLUSTER_SSL_ENABLED));
+      if (this.sourceMap.get(CLUSTER_SSL_CIPHERS) != null) {
         this.serverSslCiphers = this.clusterSSLCiphers;
-        this.sourceMap.put(SERVER_SSL_CIPHERS,this.sourceMap.get(CLUSTER_SSL_CIPHERS));
+        this.sourceMap.put(SERVER_SSL_CIPHERS, this.sourceMap.get(CLUSTER_SSL_CIPHERS));
       }
-      
-      if(this.sourceMap.get(CLUSTER_SSL_PROTOCOLS)!=null) {
+
+      if (this.sourceMap.get(CLUSTER_SSL_PROTOCOLS) != null) {
         this.serverSslProtocols = this.clusterSSLProtocols;
-        this.sourceMap.put(SERVER_SSL_PROTOCOLS,this.sourceMap.get(CLUSTER_SSL_PROTOCOLS));
+        this.sourceMap.put(SERVER_SSL_PROTOCOLS, this.sourceMap.get(CLUSTER_SSL_PROTOCOLS));
       }
-      
-      if(this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION)!=null) {
+
+      if (this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION) != null) {
         this.serverSslRequireAuthentication = this.clusterSSLRequireAuthentication;
-        this.sourceMap.put(SERVER_SSL_REQUIRE_AUTHENTICATION,this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION));
-      }      
+        this.sourceMap.put(SERVER_SSL_REQUIRE_AUTHENTICATION, this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION));
+      }
 
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
         this.serverSSLKeyStore = this.clusterSSLKeyStore;
-        this.sourceMap.put(SERVER_SSL_KEYSTORE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
+        this.sourceMap.put(SERVER_SSL_KEYSTORE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
         this.serverSSLKeyStoreType = this.clusterSSLKeyStoreType;
-        this.sourceMap.put(SERVER_SSL_KEYSTORE_TYPE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
+        this.sourceMap.put(SERVER_SSL_KEYSTORE_TYPE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
         this.serverSSLKeyStorePassword = this.clusterSSLKeyStorePassword;
-        this.sourceMap.put(SERVER_SSL_KEYSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
+        this.sourceMap.put(SERVER_SSL_KEYSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE)!=null) {
-        this.serverSSLTrustStore= this.clusterSSLTrustStore;
-        this.sourceMap.put(SERVER_SSL_TRUSTSTORE,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
+      if (this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
+        this.serverSSLTrustStore = this.clusterSSLTrustStore;
+        this.sourceMap.put(SERVER_SSL_TRUSTSTORE, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD)!=null) {
-        this.serverSSLTrustStorePassword= this.clusterSSLTrustStorePassword;
-        this.sourceMap.put(SERVER_SSL_TRUSTSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
+      if (this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
+        this.serverSSLTrustStorePassword = this.clusterSSLTrustStorePassword;
+        this.sourceMap.put(SERVER_SSL_TRUSTSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
       }
       this.serverSslProperties.putAll(this.clusterSSLProperties);
-    }   
-    
-    if(cacheServerSSLOverriden){
-      if(this.sourceMap.get(SERVER_SSL_KEYSTORE)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
+    }
+
+    if (cacheServerSSLOverriden) {
+      if (this.sourceMap.get(SERVER_SSL_KEYSTORE) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
         this.serverSSLKeyStore = this.clusterSSLKeyStore;
-        this.sourceMap.put(SERVER_SSL_KEYSTORE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
+        this.sourceMap.put(SERVER_SSL_KEYSTORE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
       }
-      if(this.sourceMap.get(SERVER_SSL_KEYSTORE_TYPE)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
+      if (this.sourceMap.get(SERVER_SSL_KEYSTORE_TYPE) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
         this.serverSSLKeyStoreType = this.clusterSSLKeyStoreType;
-        this.sourceMap.put(SERVER_SSL_KEYSTORE_TYPE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
+        this.sourceMap.put(SERVER_SSL_KEYSTORE_TYPE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
       }
-      if(this.sourceMap.get(SERVER_SSL_KEYSTORE_PASSWORD)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
+      if (this.sourceMap.get(SERVER_SSL_KEYSTORE_PASSWORD) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
         this.serverSSLKeyStorePassword = this.clusterSSLKeyStorePassword;
-        this.sourceMap.put(SERVER_SSL_KEYSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
+        this.sourceMap.put(SERVER_SSL_KEYSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
       }
-      if(this.sourceMap.get(SERVER_SSL_TRUSTSTORE)==null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
-        this.serverSSLTrustStore= this.clusterSSLTrustStore;
-        this.sourceMap.put(SERVER_SSL_TRUSTSTORE,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
+      if (this.sourceMap.get(SERVER_SSL_TRUSTSTORE) == null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
+        this.serverSSLTrustStore = this.clusterSSLTrustStore;
+        this.sourceMap.put(SERVER_SSL_TRUSTSTORE, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
       }
-      if(this.sourceMap.get(SERVER_SSL_TRUSTSTORE_PASSWORD)==null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
-        this.serverSSLTrustStorePassword= this.clusterSSLTrustStorePassword;
-        this.sourceMap.put(SERVER_SSL_TRUSTSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
+      if (this.sourceMap.get(SERVER_SSL_TRUSTSTORE_PASSWORD) == null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
+        this.serverSSLTrustStorePassword = this.clusterSSLTrustStorePassword;
+        this.sourceMap.put(SERVER_SSL_TRUSTSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
       }
     }
   }
@@ -1086,88 +1061,88 @@ public class DistributionConfigImpl
    * if gateway-ssl-*properties are given then use them, and copy the unspecified gateway properties from cluster-properties 
    */
   private void copyClusterSSLPropsToGatewaySSLProps() {
-    boolean gatewaySSLOverriden = this.sourceMap.get(GATEWAY_SSL_ENABLED)!=null;
-    boolean clusterSSLOverRidden = this.sourceMap.get(CLUSTER_SSL_ENABLED)!=null;
-    
-    if(clusterSSLOverRidden && !gatewaySSLOverriden) {
-      this.gatewaySSLEnabled  = this.clusterSSLEnabled;
-      this.sourceMap.put(GATEWAY_SSL_ENABLED,this.sourceMap.get(CLUSTER_SSL_ENABLED));
-      if(this.sourceMap.get(CLUSTER_SSL_CIPHERS)!=null) {
+    boolean gatewaySSLOverriden = this.sourceMap.get(GATEWAY_SSL_ENABLED) != null;
+    boolean clusterSSLOverRidden = this.sourceMap.get(CLUSTER_SSL_ENABLED) != null;
+
+    if (clusterSSLOverRidden && !gatewaySSLOverriden) {
+      this.gatewaySSLEnabled = this.clusterSSLEnabled;
+      this.sourceMap.put(GATEWAY_SSL_ENABLED, this.sourceMap.get(CLUSTER_SSL_ENABLED));
+      if (this.sourceMap.get(CLUSTER_SSL_CIPHERS) != null) {
         this.gatewaySslCiphers = this.clusterSSLCiphers;
-        this.sourceMap.put(GATEWAY_SSL_CIPHERS,this.sourceMap.get(CLUSTER_SSL_CIPHERS));
+        this.sourceMap.put(GATEWAY_SSL_CIPHERS, this.sourceMap.get(CLUSTER_SSL_CIPHERS));
       }
-      
-      if(this.sourceMap.get(CLUSTER_SSL_PROTOCOLS)!=null) {
+
+      if (this.sourceMap.get(CLUSTER_SSL_PROTOCOLS) != null) {
         this.gatewaySslProtocols = this.clusterSSLProtocols;
-        this.sourceMap.put(GATEWAY_SSL_PROTOCOLS,this.sourceMap.get(CLUSTER_SSL_PROTOCOLS));
+        this.sourceMap.put(GATEWAY_SSL_PROTOCOLS, this.sourceMap.get(CLUSTER_SSL_PROTOCOLS));
       }
-      
-      if(this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION)!=null) {
+
+      if (this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION) != null) {
         this.gatewaySslRequireAuthentication = this.clusterSSLRequireAuthentication;
-        this.sourceMap.put(GATEWAY_SSL_REQUIRE_AUTHENTICATION,this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION));
-      }      
+        this.sourceMap.put(GATEWAY_SSL_REQUIRE_AUTHENTICATION, this.sourceMap.get(CLUSTER_SSL_REQUIRE_AUTHENTICATION));
+      }
 
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
         this.gatewaySSLKeyStore = this.clusterSSLKeyStore;
-        this.sourceMap.put(GATEWAY_SSL_KEYSTORE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
+        this.sourceMap.put(GATEWAY_SSL_KEYSTORE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
         this.gatewaySSLKeyStoreType = this.clusterSSLKeyStoreType;
-        this.sourceMap.put(GATEWAY_SSL_KEYSTORE_TYPE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
+        this.sourceMap.put(GATEWAY_SSL_KEYSTORE_TYPE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD)!=null) {
+      if (this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
         this.gatewaySSLKeyStorePassword = this.clusterSSLKeyStorePassword;
-        this.sourceMap.put(GATEWAY_SSL_KEYSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
+        this.sourceMap.put(GATEWAY_SSL_KEYSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE)!=null) {
-        this.gatewaySSLTrustStore= this.clusterSSLTrustStore;
-        this.sourceMap.put(GATEWAY_SSL_TRUSTSTORE,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
+      if (this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
+        this.gatewaySSLTrustStore = this.clusterSSLTrustStore;
+        this.sourceMap.put(GATEWAY_SSL_TRUSTSTORE, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
       }
-      if(this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD)!=null) {
-        this.gatewaySSLTrustStorePassword= this.clusterSSLTrustStorePassword;
-        this.sourceMap.put(GATEWAY_SSL_TRUSTSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
+      if (this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
+        this.gatewaySSLTrustStorePassword = this.clusterSSLTrustStorePassword;
+        this.sourceMap.put(GATEWAY_SSL_TRUSTSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
       }
       this.gatewaySslProperties.putAll(this.clusterSSLProperties);
-    }   
-    
-    if(gatewaySSLOverriden){
-      if(this.sourceMap.get(GATEWAY_SSL_KEYSTORE)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
+    }
+
+    if (gatewaySSLOverriden) {
+      if (this.sourceMap.get(GATEWAY_SSL_KEYSTORE) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE) != null) {
         this.gatewaySSLKeyStore = this.clusterSSLKeyStore;
-        this.sourceMap.put(GATEWAY_SSL_KEYSTORE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
+        this.sourceMap.put(GATEWAY_SSL_KEYSTORE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE));
       }
-      if(this.sourceMap.get(GATEWAY_SSL_KEYSTORE_TYPE)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
+      if (this.sourceMap.get(GATEWAY_SSL_KEYSTORE_TYPE) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE) != null) {
         this.gatewaySSLKeyStoreType = this.clusterSSLKeyStoreType;
-        this.sourceMap.put(GATEWAY_SSL_KEYSTORE_TYPE,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
+        this.sourceMap.put(GATEWAY_SSL_KEYSTORE_TYPE, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_TYPE));
       }
-      if(this.sourceMap.get(GATEWAY_SSL_KEYSTORE_PASSWORD)==null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
+      if (this.sourceMap.get(GATEWAY_SSL_KEYSTORE_PASSWORD) == null && this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD) != null) {
         this.gatewaySSLKeyStorePassword = this.clusterSSLKeyStorePassword;
-        this.sourceMap.put(GATEWAY_SSL_KEYSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
+        this.sourceMap.put(GATEWAY_SSL_KEYSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_KEYSTORE_PASSWORD));
       }
-      if(this.sourceMap.get(GATEWAY_SSL_TRUSTSTORE)==null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE)!= null) {
-        this.gatewaySSLTrustStore= this.clusterSSLTrustStore;
-        this.sourceMap.put(GATEWAY_SSL_TRUSTSTORE,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
+      if (this.sourceMap.get(GATEWAY_SSL_TRUSTSTORE) == null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE) != null) {
+        this.gatewaySSLTrustStore = this.clusterSSLTrustStore;
+        this.sourceMap.put(GATEWAY_SSL_TRUSTSTORE, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE));
       }
-      if(this.sourceMap.get(GATEWAY_SSL_TRUSTSTORE_PASSWORD)==null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
-        this.gatewaySSLTrustStorePassword= this.clusterSSLTrustStorePassword;
-        this.sourceMap.put(GATEWAY_SSL_TRUSTSTORE_PASSWORD,this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
+      if (this.sourceMap.get(GATEWAY_SSL_TRUSTSTORE_PASSWORD) == null && this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD) != null) {
+        this.gatewaySSLTrustStorePassword = this.clusterSSLTrustStorePassword;
+        this.sourceMap.put(GATEWAY_SSL_TRUSTSTORE_PASSWORD, this.sourceMap.get(CLUSTER_SSL_TRUSTSTORE_PASSWORD));
       }
     }
   }
-  
-  
+
+
   private void computeMcastPortDefault() {
     // a no-op since multicast discovery has been removed
     // and the default mcast port is now zero
 
     //    ConfigSource cs = getAttSourceMap().get(ConfigurationProperties.MCAST_PORT);
-//    if (cs == null) {
-//      String locators = getLocators();
-//      if (locators != null && !locators.isEmpty()) {
-//        this.mcastPort = 0; // fixes 46308
-//      }
-//    }
+    //    if (cs == null) {
+    //      String locators = getLocators();
+    //      if (locators != null && !locators.isEmpty()) {
+    //        this.mcastPort = 0; // fixes 46308
+    //      }
+    //    }
   }
-  
+
   /**
    * Produce a DistributionConfigImpl for the given properties and return it.
    */
@@ -1180,7 +1155,7 @@ public class DistributionConfigImpl
     }
     return new DistributionConfigImpl(props, false, false);
   }
-  
+
   /**
    * Produce a DistributionConfigImpl for the given properties and return it.
    */
@@ -1200,13 +1175,13 @@ public class DistributionConfigImpl
       this.modifiable = true;
       Iterator it = apiProps.entrySet().iterator();
       while (it.hasNext()) {
-        Map.Entry me = (Map.Entry)it.next();
-        String propName = (String)me.getKey();
+        Map.Entry me = (Map.Entry) it.next();
+        String propName = (String) me.getKey();
         this.props.put(propName, me.getValue());
         if (specialPropName(propName)) {
           continue;
         }
-        String propVal = (String)me.getValue();
+        String propVal = (String) me.getValue();
         if (propVal != null) {
           this.setAttribute(propName, propVal.trim(), this.sourceMap.get(propName));
         }
@@ -1216,19 +1191,18 @@ public class DistributionConfigImpl
       this.modifiable = false;
     }
   }
-  
+
   public static boolean specialPropName(String propName) {
-    return propName.equalsIgnoreCase(SSL_ENABLED) ||
-        propName.equalsIgnoreCase(CLUSTER_SSL_ENABLED) ||
-        propName.equals(SECURITY_PEER_AUTH_INIT) ||
-        propName.equals(SECURITY_PEER_AUTHENTICATOR) ||
-        propName.equals(LOG_WRITER_NAME) ||
-        propName.equals(DS_CONFIG_NAME) ||
-        propName.equals(SECURITY_LOG_WRITER_NAME) ||
-        propName.equals(LOG_OUTPUTSTREAM_NAME) ||
-        propName.equals(SECURITY_LOG_OUTPUTSTREAM_NAME);
+    return propName.equalsIgnoreCase(CLUSTER_SSL_ENABLED) ||
+           propName.equals(SECURITY_PEER_AUTH_INIT) ||
+           propName.equals(SECURITY_PEER_AUTHENTICATOR) ||
+           propName.equals(LOG_WRITER_NAME) ||
+           propName.equals(DS_CONFIG_NAME) ||
+           propName.equals(SECURITY_LOG_WRITER_NAME) ||
+           propName.equals(LOG_OUTPUTSTREAM_NAME) ||
+           propName.equals(SECURITY_LOG_OUTPUTSTREAM_NAME);
   }
-  
+
   @Override
   protected Map<String, ConfigSource> getAttSourceMap() {
     return this.sourceMap;
@@ -1241,31 +1215,25 @@ public class DistributionConfigImpl
   /**
    * Loads the properties from gemfire.properties & gfsecurity.properties files
    * into given Properties object.
-   * 
-   * @param p
-   *          the Properties to fill in
-   * @throws GemFireIOException
-   *           when error occurs while reading properties file
+   * @param p the Properties to fill in
+   *
+   * @throws GemFireIOException when error occurs while reading properties file
    */
   public static void loadGemFireProperties(Properties p) throws GemFireIOException {
     loadGemFireProperties(p, false);
   }
-  
+
   /**
    * Loads the properties from gemfire.properties & gfsecurity.properties files
    * into given Properties object. if <code>ignoreGemFirePropsFile</code> is
    * <code>true</code>, properties are not read from gemfire.properties.
-   * 
-   * @param p
-   *          the Properties to fill in
-   * @param ignoreGemFirePropsFile
-   *          whether to ignore properties from gemfire.properties
-   * @throws GemFireIOException
-   *           when error occurs while reading properties file
+   * @param p the Properties to fill in
+   * @param ignoreGemFirePropsFile whether to ignore properties from gemfire.properties
+   *
+   * @throws GemFireIOException when error occurs while reading properties file
    */
   // Fix for #44924
-  public static void loadGemFireProperties(Properties p, 
-                    boolean ignoreGemFirePropsFile) throws GemFireIOException {
+  public static void loadGemFireProperties(Properties p, boolean ignoreGemFirePropsFile) throws GemFireIOException {
     if (!ignoreGemFirePropsFile) {
       loadPropertiesFromURL(p, DistributedSystem.getPropertyFileURL());
     }
@@ -1280,11 +1248,11 @@ public class DistributionConfigImpl
     if (source == null) {
       throw new IllegalArgumentException("Valid ConfigSource must be specified instead of null.");
     }
-    for (Object k: p.keySet()) {
-      this.sourceMap.put((String)k, source);
+    for (Object k : p.keySet()) {
+      this.sourceMap.put((String) k, source);
     }
   }
-  
+
   private Properties loadPropertiesFromURL(URL url, boolean secure) {
     Properties result = new Properties();
     loadPropertiesFromURL(result, url);
@@ -1293,7 +1261,7 @@ public class DistributionConfigImpl
     }
     return result;
   }
-  
+
   private static void loadPropertiesFromURL(Properties p, URL url) {
     if (url != null) {
       try {
@@ -1303,43 +1271,35 @@ public class DistributionConfigImpl
       }
     }
   }
-  
+
   private void initialize(Map props) {
     // Allow attributes to be modified
     this.modifiable = true;
     this.props = props;
     Iterator it = props.entrySet().iterator();
     while (it.hasNext()) {
-      Map.Entry me = (Map.Entry)it.next();
-      String propName = (String)me.getKey();
+      Map.Entry me = (Map.Entry) it.next();
+      String propName = (String) me.getKey();
       // if ssl-enabled is set to true before the mcast port is set to 0, then it will error.
       // security should not be enabled before the mcast port is set to 0.
       if (specialPropName(propName)) {
         continue;
       }
       Object propVal = me.getValue();
-      if (propVal != null  &&  (propVal instanceof String)) { // weed out extraneous non-string properties
-        this.setAttribute(propName, ((String)propVal).trim(), this.sourceMap.get(propName));
+      if (propVal != null && (propVal instanceof String)) { // weed out extraneous non-string properties
+        this.setAttribute(propName, ((String) propVal).trim(), this.sourceMap.get(propName));
       }
     }
-    // now set ssl-enabled if needed...
-    if ( props.containsKey(SSL_ENABLED) ) {
-      this.setAttribute(SSL_ENABLED, (String) props.get( SSL_ENABLED ), this.sourceMap.get(SSL_ENABLED) );
-    }
-    if ( props.containsKey(CLUSTER_SSL_ENABLED) ) {
-      this.setAttribute(CLUSTER_SSL_ENABLED, (String) props.get( CLUSTER_SSL_ENABLED ), this.sourceMap.get(CLUSTER_SSL_ENABLED) );
+    if (props.containsKey(CLUSTER_SSL_ENABLED)) {
+      this.setAttribute(CLUSTER_SSL_ENABLED, (String) props.get(CLUSTER_SSL_ENABLED), this.sourceMap.get(CLUSTER_SSL_ENABLED));
     }
     // now set the security authInit if needed
     if (props.containsKey(SECURITY_PEER_AUTH_INIT)) {
-      this.setAttribute(SECURITY_PEER_AUTH_INIT, (String)props
-          .get(SECURITY_PEER_AUTH_INIT),
-          this.sourceMap.get(SECURITY_PEER_AUTH_INIT));
+      this.setAttribute(SECURITY_PEER_AUTH_INIT, (String) props.get(SECURITY_PEER_AUTH_INIT), this.sourceMap.get(SECURITY_PEER_AUTH_INIT));
     }
     // and security authenticator if needed
     if (props.containsKey(SECURITY_PEER_AUTHENTICATOR)) {
-      this.setAttribute(SECURITY_PEER_AUTHENTICATOR, (String)props
-          .get(SECURITY_PEER_AUTHENTICATOR),
-          this.sourceMap.get(SECURITY_PEER_AUTHENTICATOR));
+      this.setAttribute(SECURITY_PEER_AUTHENTICATOR, (String) props.get(SECURITY_PEER_AUTHENTICATOR), this.sourceMap.get(SECURITY_PEER_AUTHENTICATOR));
     }
 
     // Make attributes read only
@@ -1354,7 +1314,7 @@ public class DistributionConfigImpl
 
     Iterator iter = security.keySet().iterator();
     while (iter.hasNext()) {
-      props.remove(SECURITY_SYSTEM_PREFIX + (String)iter.next());
+      props.remove(SECURITY_SYSTEM_PREFIX + (String) iter.next());
     }
     System.setProperties(props);
   }
@@ -1372,35 +1332,39 @@ public class DistributionConfigImpl
   public int getMcastPort() {
     return this.mcastPort;
   }
+
   public int getMcastTtl() {
     return this.mcastTtl;
   }
+
   public int getSocketLeaseTime() {
     return this.socketLeaseTime;
   }
+
   public int getSocketBufferSize() {
     return this.socketBufferSize;
   }
+
   public boolean getConserveSockets() {
     return this.conserveSockets;
   }
+
   public String getRoles() {
     return this.roles;
   }
 
-  public int getMaxWaitTimeForReconnect(){
-  return this.maxWaitTimeForReconnect;
+  public int getMaxWaitTimeForReconnect() {
+    return this.maxWaitTimeForReconnect;
   }
 
-  public int getMaxNumReconnectTries(){
+  public int getMaxNumReconnectTries() {
     return this.maxNumReconnectTries;
   }
 
   public InetAddress getMcastAddress() {
     try {
       return this.mcastAddress;
-    }
-    catch (Exception e) {
+    } catch (Exception e) {
       e.printStackTrace();
       return null;
     }
@@ -1437,12 +1401,11 @@ public class DistributionConfigImpl
   public String getStartLocator() {
     if (this.startLocatorPort > 0) {
       if (this.bindAddress != null) {
-        return this.bindAddress + "["+this.startLocatorPort+"]";
+        return this.bindAddress + "[" + this.startLocatorPort + "]";
       }
       try {
-        return SocketCreator.getHostName(SocketCreator.getLocalHost()) + "["+this.startLocatorPort+"]";
-      }
-      catch (UnknownHostException e) {
+        return SocketCreator.getHostName(SocketCreator.getLocalHost()) + "[" + this.startLocatorPort + "]";
+      } catch (UnknownHostException e) {
         // punt and use this.startLocator instead
       }
     }
@@ -1485,63 +1448,50 @@ public class DistributionConfigImpl
     return this.cacheXmlFile;
   }
 
-  public boolean getSSLEnabled( ) {
-    return this.sslEnabled;
-  }
-
-  public String getSSLProtocols( ) {
-    return this.sslProtocols;
-  }
-
-  public String getSSLCiphers( ) {
-    return this.sslCiphers;
-  }
-
-  public boolean getSSLRequireAuthentication( ) {
-    return this.sslRequireAuthentication;
-  }
-
-  public boolean getClusterSSLEnabled( ) {
+  public boolean getClusterSSLEnabled() {
     return this.clusterSSLEnabled;
   }
 
-  public String getClusterSSLProtocols( ) {
+  public String getClusterSSLProtocols() {
     return this.clusterSSLProtocols;
   }
 
-  public String getClusterSSLCiphers( ) {
+  public String getClusterSSLCiphers() {
     return this.clusterSSLCiphers;
   }
 
-  public boolean getClusterSSLRequireAuthentication( ) {
+  public boolean getClusterSSLRequireAuthentication() {
     return this.clusterSSLRequireAuthentication;
   }
-  
-  public String getClusterSSLKeyStore( ){
+
+  public String getClusterSSLKeyStore() {
     return this.clusterSSLKeyStore;
   }
-  public String getClusterSSLKeyStoreType( ){
+
+  public String getClusterSSLKeyStoreType() {
     return this.clusterSSLKeyStoreType;
   }
-  
-  public String getClusterSSLKeyStorePassword( ){
+
+  public String getClusterSSLKeyStorePassword() {
     return this.clusterSSLKeyStorePassword;
   }
-  
-  public String getClusterSSLTrustStore( ){
+
+  public String getClusterSSLTrustStore() {
     return this.clusterSSLTrustStore;
   }
-  
-  public String getClusterSSLTrustStorePassword( ){
+
+  public String getClusterSSLTrustStorePassword() {
     return this.clusterSSLTrustStorePassword;
   }
-  
+
   public int getAsyncDistributionTimeout() {
     return this.asyncDistributionTimeout;
   }
+
   public int getAsyncQueueTimeout() {
     return this.asyncQueueTimeout;
   }
+
   public int getAsyncMaxQueueSize() {
     return this.asyncMaxQueueSize;
   }
@@ -1549,33 +1499,33 @@ public class DistributionConfigImpl
   public String getUserCommandPackages() {
     return this.userCommandPackages;
   }
-    
+
   public int getHttpServicePort() {
     return this.httpServicePort;
   }
 
   public void setHttpServicePort(int value) {
-    this.httpServicePort = (Integer)checkAttribute(HTTP_SERVICE_PORT, value);
+    this.httpServicePort = (Integer) checkAttribute(HTTP_SERVICE_PORT, value);
   }
-  
+
   public String getHttpServiceBindAddress() {
     return this.httpServiceBindAddress;
   }
-  
+
   public void setHttpServiceBindAddress(String value) {
-    this.httpServiceBindAddress = (String)checkAttribute(HTTP_SERVICE_BIND_ADDRESS, value);
+    this.httpServiceBindAddress = (String) checkAttribute(HTTP_SERVICE_BIND_ADDRESS, value);
   }
-  
-  public boolean getStartDevRestApi(){
+
+  public boolean getStartDevRestApi() {
     return this.startDevRestApi;
   }
-  
-  public void setStartDevRestApi(boolean value){
+
+  public void setStartDevRestApi(boolean value) {
     this.startDevRestApi = value;
   }
- 
+
   public void setUserCommandPackages(String value) {
-    this.userCommandPackages = (String)checkAttribute(USER_COMMAND_PACKAGES, value);
+    this.userCommandPackages = (String) checkAttribute(USER_COMMAND_PACKAGES, value);
   }
 
   public boolean getDeltaPropagation() {
@@ -1583,7 +1533,7 @@ public class DistributionConfigImpl
   }
 
   public void setDeltaPropagation(boolean value) {
-    this.deltaPropagation = (Boolean)checkAttribute(DELTA_PROPAGATION, value);
+    this.deltaPropagation = (Boolean) checkAttribute(DELTA_PROPAGATION, value);
   }
 
   public void setName(String value) {
@@ -1592,69 +1542,82 @@ public class DistributionConfigImpl
     }
     this.name = (String) checkAttribute(NAME, value);
   }
+
   public void setTcpPort(int value) {
     this.tcpPort = (Integer) checkAttribute(TCP_PORT, value);
   }
+
   public void setMcastPort(int value) {
     this.mcastPort = (Integer) checkAttribute(MCAST_PORT, value);
   }
+
   public void setMcastTtl(int value) {
     this.mcastTtl = (Integer) checkAttribute(MCAST_TTL, value);
   }
+
   public void setSocketLeaseTime(int value) {
-    this.socketLeaseTime = (Integer)checkAttribute(SOCKET_LEASE_TIME, value);
+    this.socketLeaseTime = (Integer) checkAttribute(SOCKET_LEASE_TIME, value);
   }
+
   public void setSocketBufferSize(int value) {
-    this.socketBufferSize = (Integer)checkAttribute(SOCKET_BUFFER_SIZE, value);
+    this.socketBufferSize = (Integer) checkAttribute(SOCKET_BUFFER_SIZE, value);
   }
+
   public void setConserveSockets(boolean value) {
-    this.conserveSockets = (Boolean)checkAttribute(CONSERVE_SOCKETS, value);
+    this.conserveSockets = (Boolean) checkAttribute(CONSERVE_SOCKETS, value);
   }
+
   public void setRoles(String value) {
-    this.roles = (String)checkAttribute(ROLES, value);
+    this.roles = (String) checkAttribute(ROLES, value);
   }
 
-  public void setMaxWaitTimeForReconnect(int value){
+  public void setMaxWaitTimeForReconnect(int value) {
     this.maxWaitTimeForReconnect = value;
   }
 
-  public void setMaxNumReconnectTries(int value){
+  public void setMaxNumReconnectTries(int value) {
     this.maxNumReconnectTries = value;
   }
 
   public void setMcastAddress(InetAddress value) {
     this.mcastAddress = (InetAddress) checkAttribute(MCAST_ADDRESS, value);
   }
+
   public void setBindAddress(String value) {
     this.bindAddress = (String) checkAttribute(BIND_ADDRESS, value);
   }
+
   public void setServerBindAddress(String value) {
     this.serverBindAddress = (String) checkAttribute(SERVER_BIND_ADDRESS, value);
   }
+
   public void setLocators(String value) {
     if (value == null) {
       value = DEFAULT_LOCATORS;
     }
     this.locators = (String) checkAttribute(LOCATORS, value);
   }
-  
+
   public void setLocatorWaitTime(int value) {
     this.locatorWaitTime = value;
   }
-  
+
   public int getLocatorWaitTime() {
     return this.locatorWaitTime;
   }
-  
+
   public void setDeployWorkingDir(File value) {
-    this.deployWorkingDir = (File)checkAttribute(DEPLOY_WORKING_DIR, value);
+    this.deployWorkingDir = (File) checkAttribute(DEPLOY_WORKING_DIR, value);
   }
+
   public void setLogFile(File value) {
-    this.logFile = (File)checkAttribute(LOG_FILE, value);
+    this.logFile = (File) checkAttribute(LOG_FILE, value);
   }
+
   public void setLogLevel(int value) {
-    this.logLevel = (Integer)checkAttribute(LOG_LEVEL, value);
+    this.logLevel = (Integer) checkAttribute(LOG_LEVEL, value);
   }
+
   /**
    * the locator startup code must be able to modify the locator log file in order
    * to establish a default log file if one hasn't been specified by the user.
@@ -1664,15 +1627,15 @@ public class DistributionConfigImpl
   public void unsafeSetLogFile(File value) {
     this.logFile = value;
   }
+
   public void setStartLocator(String value) {
     startLocatorPort = 0;
     if (value == null) {
       value = DEFAULT_START_LOCATOR;
-    }
-    else {
+    } else {
       // bug 37938 - allow just a port
       boolean alldigits = true;
-      for (int i=0; i<value.length(); i++) {
+      for (int i = 0; i < value.length(); i++) {
         char c = value.charAt(i);
         if (!Character.isDigit(c)) {
           alldigits = false;
@@ -1686,131 +1649,137 @@ public class DistributionConfigImpl
             throw new GemFireConfigException("Illegal port specified for start-locator");
           }
           startLocatorPort = port;
-        }
-        catch (NumberFormatException e) {
+        } catch (NumberFormatException e) {
           throw new GemFireConfigException("Illegal port specified for start-locator", e);
         }
-      }
-      else {
+      } else {
         value = (String) checkAttribute(START_LOCATOR, value);
       }
     }
     this.startLocator = value;
   }
+
   public void setStatisticSamplingEnabled(boolean value) {
-    this.statisticSamplingEnabled = (Boolean)checkAttribute(STATISTIC_SAMPLING_ENABLED, value);
+    this.statisticSamplingEnabled = (Boolean) checkAttribute(STATISTIC_SAMPLING_ENABLED, value);
   }
+
   public void setStatisticSampleRate(int value) {
-    value = (Integer)checkAttribute(STATISTIC_SAMPLE_RATE, value);
+    value = (Integer) checkAttribute(STATISTIC_SAMPLE_RATE, value);
     if (value < DEFAULT_STATISTIC_SAMPLE_RATE) {
       // fix 48228
       InternalDistributedSystem ids = InternalDistributedSystem.getConnectedInstance();
       if (ids != null) {
-        ids.getLogWriter().info("Setting statistic-sample-rate to " + DEFAULT_STATISTIC_SAMPLE_RATE + " instead of the requested " + value + " because VSD does not work with sub-second sampling.");
+        ids.getLogWriter()
+           .info("Setting statistic-sample-rate to " + DEFAULT_STATISTIC_SAMPLE_RATE + " instead of the requested " + value + " because VSD does not work with sub-second sampling.");
       }
       value = DEFAULT_STATISTIC_SAMPLE_RATE;
     }
     this.statisticSampleRate = value;
   }
+
   public void setStatisticArchiveFile(File value) {
     if (value == null) {
       value = new File("");
     }
-    this.statisticArchiveFile = (File)checkAttribute(STATISTIC_ARCHIVE_FILE, value);
+    this.statisticArchiveFile = (File) checkAttribute(STATI

<TRUNCATED>