You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@druid.apache.org by jo...@apache.org on 2019/02/01 01:59:44 UTC

[incubator-druid] branch master updated: Some adjustments to config examples. (#6973)

This is an automated email from the ASF dual-hosted git repository.

jonwei pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-druid.git


The following commit(s) were added to refs/heads/master by this push:
     new 4e42632  Some adjustments to config examples. (#6973)
4e42632 is described below

commit 4e426327bb51674a2112b17ba6347405837beef2
Author: Gian Merlino <gi...@gmail.com>
AuthorDate: Thu Jan 31 17:59:39 2019 -0800

    Some adjustments to config examples. (#6973)
    
    * Some adjustments to config examples.
    
    - Add ExitOnOutOfMemoryError to jvm.config examples. It was added a
    pretty long time ago (8u92) and is helpful since it prevents zombie
    processes from hanging around. (OOMEs tend to bork things)
    - Disable Broker caching and enable it on Historicals in example
    configs. This config tends to scale better since it enables the
    Historicals to merge results rather than sending everything by-segment
    to the Broker. Also switch to "caffeine" cache from "local".
    - Increase concurrency a bit for Broker example config.
    - Enable SQL in the example config, a baby step towards making SQL
    more of a thing. (It's still off by default in the code.)
    - Reduce memory use a bit for the quickstart configs.
    - Add example Router configs, in case someone wants to use that. One
    reason might be to get the fancy new console (#6923).
    
    * Add example Router configs.
    
    * Fix up router example properties.
    
    * Add router to quickstart supervise conf.
---
 .../conf/druid/_common/common.runtime.properties   |  5 +++
 examples/conf/druid/broker/jvm.config              |  1 +
 examples/conf/druid/broker/runtime.properties      | 19 +++++-----
 examples/conf/druid/coordinator/jvm.config         |  1 +
 examples/conf/druid/historical/jvm.config          |  1 +
 examples/conf/druid/historical/runtime.properties  |  6 ++++
 examples/conf/druid/middleManager/jvm.config       |  1 +
 .../conf/druid/middleManager/runtime.properties    |  2 +-
 examples/conf/druid/overlord/jvm.config            |  1 +
 .../conf/druid/{historical => router}/jvm.config   |  8 +++--
 .../{historical => router}/runtime.properties      | 22 ++++++------
 .../tutorial/conf/druid/broker/jvm.config          |  7 ++--
 .../tutorial/conf/druid/broker/runtime.properties  | 42 ++++++++++++++++------
 .../tutorial/conf/druid/coordinator/jvm.config     |  5 +--
 .../conf/druid/coordinator/runtime.properties      | 19 ++++++++++
 .../tutorial/conf/druid/historical/jvm.config      |  7 ++--
 .../conf/druid/historical/runtime.properties       | 31 ++++++++++++++--
 .../tutorial/conf/druid/middleManager/jvm.config   |  1 +
 .../conf/druid/middleManager/runtime.properties    | 21 ++++++++++-
 .../tutorial/conf/druid/overlord/jvm.config        |  5 +--
 .../conf/druid/overlord/runtime.properties         | 19 ++++++++++
 .../tutorial/conf/druid/router}/jvm.config         |  8 +++--
 .../tutorial/conf/druid/router}/runtime.properties | 22 ++++++------
 .../quickstart/tutorial/conf/tutorial-cluster.conf |  1 +
 24 files changed, 196 insertions(+), 59 deletions(-)

diff --git a/examples/conf/druid/_common/common.runtime.properties b/examples/conf/druid/_common/common.runtime.properties
index b7d1870..9db6060 100644
--- a/examples/conf/druid/_common/common.runtime.properties
+++ b/examples/conf/druid/_common/common.runtime.properties
@@ -120,3 +120,8 @@ druid.emitter.logging.logLevel=info
 # ommiting this will lead to index double as float at the storage layer
 
 druid.indexing.doubleStorage=double
+
+#
+# SQL
+#
+druid.sql.enable=true
diff --git a/examples/conf/druid/broker/jvm.config b/examples/conf/druid/broker/jvm.config
index a6a9982..cf67f93 100644
--- a/examples/conf/druid/broker/jvm.config
+++ b/examples/conf/druid/broker/jvm.config
@@ -2,6 +2,7 @@
 -Xms24g
 -Xmx24g
 -XX:MaxDirectMemorySize=4096m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/conf/druid/broker/runtime.properties b/examples/conf/druid/broker/runtime.properties
index 75a3ccd..9421053 100644
--- a/examples/conf/druid/broker/runtime.properties
+++ b/examples/conf/druid/broker/runtime.properties
@@ -20,16 +20,17 @@
 druid.service=druid/broker
 druid.plaintextPort=8082
 
-# HTTP server threads
-druid.broker.http.numConnections=5
-druid.server.http.numThreads=25
+# HTTP server settings
+druid.server.http.numThreads=60
+
+# HTTP client settings
+druid.broker.http.numConnections=10
 
 # Processing threads and buffers
 druid.processing.buffer.sizeBytes=536870912
-druid.processing.numThreads=7
+druid.processing.numMergeBuffers=2
+druid.processing.numThreads=1
 
-# Query cache
-druid.broker.cache.useCache=true
-druid.broker.cache.populateCache=true
-druid.cache.type=local
-druid.cache.sizeInBytes=2000000000
+# Query cache disabled -- push down caching and merging instead
+druid.broker.cache.useCache=false
+druid.broker.cache.populateCache=false
diff --git a/examples/conf/druid/coordinator/jvm.config b/examples/conf/druid/coordinator/jvm.config
index 99f6d1d..a57248d 100644
--- a/examples/conf/druid/coordinator/jvm.config
+++ b/examples/conf/druid/coordinator/jvm.config
@@ -1,6 +1,7 @@
 -server
 -Xms3g
 -Xmx3g
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/conf/druid/historical/jvm.config b/examples/conf/druid/historical/jvm.config
index 7fdbb1c..94685fe 100644
--- a/examples/conf/druid/historical/jvm.config
+++ b/examples/conf/druid/historical/jvm.config
@@ -2,6 +2,7 @@
 -Xms8g
 -Xmx8g
 -XX:MaxDirectMemorySize=4096m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/conf/druid/historical/runtime.properties b/examples/conf/druid/historical/runtime.properties
index b5562a7..e61e51c 100644
--- a/examples/conf/druid/historical/runtime.properties
+++ b/examples/conf/druid/historical/runtime.properties
@@ -30,3 +30,9 @@ druid.processing.numThreads=7
 # Segment storage
 druid.segmentCache.locations=[{"path":"var/druid/segment-cache","maxSize":130000000000}]
 druid.server.maxSize=130000000000
+
+# Query cache
+druid.historical.cache.useCache=true
+druid.historical.cache.populateCache=true
+druid.cache.type=caffeine
+druid.cache.sizeInBytes=2000000000
diff --git a/examples/conf/druid/middleManager/jvm.config b/examples/conf/druid/middleManager/jvm.config
index 7b9f1a4..8a650fb 100644
--- a/examples/conf/druid/middleManager/jvm.config
+++ b/examples/conf/druid/middleManager/jvm.config
@@ -1,6 +1,7 @@
 -server
 -Xms64m
 -Xmx64m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/conf/druid/middleManager/runtime.properties b/examples/conf/druid/middleManager/runtime.properties
index 8fb5682..8f9e8cb 100644
--- a/examples/conf/druid/middleManager/runtime.properties
+++ b/examples/conf/druid/middleManager/runtime.properties
@@ -24,7 +24,7 @@ druid.plaintextPort=8091
 druid.worker.capacity=3
 
 # Task launch parameters
-druid.indexer.runner.javaOpts=-server -Xmx2g -Duser.timezone=UTC -Dfile.encoding=UTF-8 -Djava.util.logging.manager=org.apache.logging.log4j.jul.LogManager
+druid.indexer.runner.javaOpts=-server -Xmx2g -Duser.timezone=UTC -Dfile.encoding=UTF-8 -XX:+ExitOnOutOfMemoryError -Djava.util.logging.manager=org.apache.logging.log4j.jul.LogManager
 druid.indexer.task.baseTaskDir=var/druid/task
 
 # HTTP server threads
diff --git a/examples/conf/druid/overlord/jvm.config b/examples/conf/druid/overlord/jvm.config
index 2df9a1c..59e2eaa 100644
--- a/examples/conf/druid/overlord/jvm.config
+++ b/examples/conf/druid/overlord/jvm.config
@@ -1,6 +1,7 @@
 -server
 -Xms3g
 -Xmx3g
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/conf/druid/historical/jvm.config b/examples/conf/druid/router/jvm.config
similarity index 61%
copy from examples/conf/druid/historical/jvm.config
copy to examples/conf/druid/router/jvm.config
index 7fdbb1c..37b200e 100644
--- a/examples/conf/druid/historical/jvm.config
+++ b/examples/conf/druid/router/jvm.config
@@ -1,7 +1,9 @@
 -server
--Xms8g
--Xmx8g
--XX:MaxDirectMemorySize=4096m
+-Xms512m
+-Xmx512m
+-XX:+UseG1GC
+-XX:MaxDirectMemorySize=512m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/conf/druid/historical/runtime.properties b/examples/conf/druid/router/runtime.properties
similarity index 63%
copy from examples/conf/druid/historical/runtime.properties
copy to examples/conf/druid/router/runtime.properties
index b5562a7..497d3b4 100644
--- a/examples/conf/druid/historical/runtime.properties
+++ b/examples/conf/druid/router/runtime.properties
@@ -17,16 +17,18 @@
 # under the License.
 #
 
-druid.service=druid/historical
-druid.plaintextPort=8083
+druid.service=druid/router
+druid.plaintextPort=8888
 
-# HTTP server threads
-druid.server.http.numThreads=25
+# HTTP proxy
+druid.router.http.numConnections=50
+druid.router.http.readTimeout=PT5M
+druid.router.http.numMaxThreads=100
+druid.server.http.numThreads=100
 
-# Processing threads and buffers
-druid.processing.buffer.sizeBytes=536870912
-druid.processing.numThreads=7
+# Service discovery
+druid.router.defaultBrokerServiceName=druid/broker
+druid.router.coordinatorServiceName=druid/coordinator
 
-# Segment storage
-druid.segmentCache.locations=[{"path":"var/druid/segment-cache","maxSize":130000000000}]
-druid.server.maxSize=130000000000
+# Management proxy to coordinator / overlord: required for unified web console.
+druid.router.managementProxy.enabled=true
diff --git a/examples/quickstart/tutorial/conf/druid/broker/jvm.config b/examples/quickstart/tutorial/conf/druid/broker/jvm.config
index 608aa35..076a222 100644
--- a/examples/quickstart/tutorial/conf/druid/broker/jvm.config
+++ b/examples/quickstart/tutorial/conf/druid/broker/jvm.config
@@ -1,7 +1,8 @@
 -server
--Xms1g
--Xmx1g
--XX:MaxDirectMemorySize=1792m
+-Xms256m
+-Xmx256m
+-XX:MaxDirectMemorySize=768m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/quickstart/tutorial/conf/druid/broker/runtime.properties b/examples/quickstart/tutorial/conf/druid/broker/runtime.properties
index 65c3cd9..cad3373 100644
--- a/examples/quickstart/tutorial/conf/druid/broker/runtime.properties
+++ b/examples/quickstart/tutorial/conf/druid/broker/runtime.properties
@@ -1,16 +1,38 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+
 druid.service=druid/broker
 druid.plaintextPort=8082
 
-# HTTP server threads
-druid.broker.http.numConnections=5
-druid.server.http.numThreads=9
+# HTTP server settings
+druid.server.http.numThreads=12
+
+# HTTP client settings
+druid.broker.http.numConnections=10
+druid.broker.http.maxQueuedBytes=5000000
 
 # Processing threads and buffers
-druid.processing.buffer.sizeBytes=256000000
-druid.processing.numThreads=2
+druid.processing.buffer.sizeBytes=100000000
+druid.processing.numMergeBuffers=2
+druid.processing.numThreads=1
+druid.processing.tmpDir=var/druid/processing
 
-# Query cache (we use a small local cache)
-druid.broker.cache.useCache=true
-druid.broker.cache.populateCache=true
-druid.cache.type=local
-druid.cache.sizeInBytes=10000000
+# Query cache disabled -- push down caching and merging instead
+druid.broker.cache.useCache=false
+druid.broker.cache.populateCache=false
diff --git a/examples/quickstart/tutorial/conf/druid/coordinator/jvm.config b/examples/quickstart/tutorial/conf/druid/coordinator/jvm.config
index 66aa951..162faa0 100644
--- a/examples/quickstart/tutorial/conf/druid/coordinator/jvm.config
+++ b/examples/quickstart/tutorial/conf/druid/coordinator/jvm.config
@@ -1,6 +1,7 @@
 -server
--Xms256m
--Xmx256m
+-Xms128m
+-Xmx128m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/quickstart/tutorial/conf/druid/coordinator/runtime.properties b/examples/quickstart/tutorial/conf/druid/coordinator/runtime.properties
index 8fb650d..52dd09a 100644
--- a/examples/quickstart/tutorial/conf/druid/coordinator/runtime.properties
+++ b/examples/quickstart/tutorial/conf/druid/coordinator/runtime.properties
@@ -1,3 +1,22 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+
 druid.service=druid/coordinator
 druid.plaintextPort=8081
 
diff --git a/examples/quickstart/tutorial/conf/druid/historical/jvm.config b/examples/quickstart/tutorial/conf/druid/historical/jvm.config
index 430209e..076a222 100644
--- a/examples/quickstart/tutorial/conf/druid/historical/jvm.config
+++ b/examples/quickstart/tutorial/conf/druid/historical/jvm.config
@@ -1,7 +1,8 @@
 -server
--Xms1g
--Xmx1g
--XX:MaxDirectMemorySize=1280m
+-Xms256m
+-Xmx256m
+-XX:MaxDirectMemorySize=768m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/quickstart/tutorial/conf/druid/historical/runtime.properties b/examples/quickstart/tutorial/conf/druid/historical/runtime.properties
index 10a763f..dc78b0f 100644
--- a/examples/quickstart/tutorial/conf/druid/historical/runtime.properties
+++ b/examples/quickstart/tutorial/conf/druid/historical/runtime.properties
@@ -1,13 +1,40 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+
 druid.service=druid/historical
 druid.plaintextPort=8083
 
 # HTTP server threads
-druid.server.http.numThreads=9
+druid.server.http.numThreads=12
 
 # Processing threads and buffers
-druid.processing.buffer.sizeBytes=256000000
+druid.processing.buffer.sizeBytes=100000000
+druid.processing.numMergeBuffers=1
 druid.processing.numThreads=2
+druid.processing.tmpDir=var/druid/processing
 
 # Segment storage
 druid.segmentCache.locations=[{"path":"var/druid/segment-cache","maxSize":300000000000}]
 druid.server.maxSize=300000000000
+
+# Query cache
+druid.historical.cache.useCache=true
+druid.historical.cache.populateCache=true
+druid.cache.type=caffeine
+druid.cache.sizeInBytes=10000000
diff --git a/examples/quickstart/tutorial/conf/druid/middleManager/jvm.config b/examples/quickstart/tutorial/conf/druid/middleManager/jvm.config
index 7b9f1a4..8a650fb 100644
--- a/examples/quickstart/tutorial/conf/druid/middleManager/jvm.config
+++ b/examples/quickstart/tutorial/conf/druid/middleManager/jvm.config
@@ -1,6 +1,7 @@
 -server
 -Xms64m
 -Xmx64m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/quickstart/tutorial/conf/druid/middleManager/runtime.properties b/examples/quickstart/tutorial/conf/druid/middleManager/runtime.properties
index ad12d7e..d1660aa 100644
--- a/examples/quickstart/tutorial/conf/druid/middleManager/runtime.properties
+++ b/examples/quickstart/tutorial/conf/druid/middleManager/runtime.properties
@@ -1,3 +1,22 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+
 druid.service=druid/middleManager
 druid.plaintextPort=8091
 
@@ -5,7 +24,7 @@ druid.plaintextPort=8091
 druid.worker.capacity=3
 
 # Task launch parameters
-druid.indexer.runner.javaOpts=-server -Xmx2g -Duser.timezone=UTC -Dfile.encoding=UTF-8 -Djava.util.logging.manager=org.apache.logging.log4j.jul.LogManager
+druid.indexer.runner.javaOpts=-server -Xms512m -Xmx512m -Duser.timezone=UTC -Dfile.encoding=UTF-8 -XX:+ExitOnOutOfMemoryError -Djava.util.logging.manager=org.apache.logging.log4j.jul.LogManager
 druid.indexer.task.baseTaskDir=var/druid/task
 
 # HTTP server threads
diff --git a/examples/quickstart/tutorial/conf/druid/overlord/jvm.config b/examples/quickstart/tutorial/conf/druid/overlord/jvm.config
index 90526a5..c145532 100644
--- a/examples/quickstart/tutorial/conf/druid/overlord/jvm.config
+++ b/examples/quickstart/tutorial/conf/druid/overlord/jvm.config
@@ -1,6 +1,7 @@
 -server
--Xms256m
--Xmx256m
+-Xms128m
+-Xmx128m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/quickstart/tutorial/conf/druid/overlord/runtime.properties b/examples/quickstart/tutorial/conf/druid/overlord/runtime.properties
index df1e069..093758c 100644
--- a/examples/quickstart/tutorial/conf/druid/overlord/runtime.properties
+++ b/examples/quickstart/tutorial/conf/druid/overlord/runtime.properties
@@ -1,3 +1,22 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+
 druid.service=druid/overlord
 druid.plaintextPort=8090
 
diff --git a/examples/conf/druid/historical/jvm.config b/examples/quickstart/tutorial/conf/druid/router/jvm.config
similarity index 61%
copy from examples/conf/druid/historical/jvm.config
copy to examples/quickstart/tutorial/conf/druid/router/jvm.config
index 7fdbb1c..e74d6b1 100644
--- a/examples/conf/druid/historical/jvm.config
+++ b/examples/quickstart/tutorial/conf/druid/router/jvm.config
@@ -1,7 +1,9 @@
 -server
--Xms8g
--Xmx8g
--XX:MaxDirectMemorySize=4096m
+-Xms128m
+-Xmx128m
+-XX:+UseG1GC
+-XX:MaxDirectMemorySize=128m
+-XX:+ExitOnOutOfMemoryError
 -Duser.timezone=UTC
 -Dfile.encoding=UTF-8
 -Djava.io.tmpdir=var/tmp
diff --git a/examples/conf/druid/historical/runtime.properties b/examples/quickstart/tutorial/conf/druid/router/runtime.properties
similarity index 63%
copy from examples/conf/druid/historical/runtime.properties
copy to examples/quickstart/tutorial/conf/druid/router/runtime.properties
index b5562a7..497d3b4 100644
--- a/examples/conf/druid/historical/runtime.properties
+++ b/examples/quickstart/tutorial/conf/druid/router/runtime.properties
@@ -17,16 +17,18 @@
 # under the License.
 #
 
-druid.service=druid/historical
-druid.plaintextPort=8083
+druid.service=druid/router
+druid.plaintextPort=8888
 
-# HTTP server threads
-druid.server.http.numThreads=25
+# HTTP proxy
+druid.router.http.numConnections=50
+druid.router.http.readTimeout=PT5M
+druid.router.http.numMaxThreads=100
+druid.server.http.numThreads=100
 
-# Processing threads and buffers
-druid.processing.buffer.sizeBytes=536870912
-druid.processing.numThreads=7
+# Service discovery
+druid.router.defaultBrokerServiceName=druid/broker
+druid.router.coordinatorServiceName=druid/coordinator
 
-# Segment storage
-druid.segmentCache.locations=[{"path":"var/druid/segment-cache","maxSize":130000000000}]
-druid.server.maxSize=130000000000
+# Management proxy to coordinator / overlord: required for unified web console.
+druid.router.managementProxy.enabled=true
diff --git a/examples/quickstart/tutorial/conf/tutorial-cluster.conf b/examples/quickstart/tutorial/conf/tutorial-cluster.conf
index c1316cc..4c2c70d 100644
--- a/examples/quickstart/tutorial/conf/tutorial-cluster.conf
+++ b/examples/quickstart/tutorial/conf/tutorial-cluster.conf
@@ -5,6 +5,7 @@
 !p10 zk bin/run-zk quickstart/tutorial/conf
 coordinator bin/run-druid coordinator quickstart/tutorial/conf
 broker bin/run-druid broker quickstart/tutorial/conf
+router bin/run-druid router quickstart/tutorial/conf
 historical bin/run-druid historical quickstart/tutorial/conf
 !p80 overlord bin/run-druid overlord quickstart/tutorial/conf
 !p90 middleManager bin/run-druid middleManager quickstart/tutorial/conf


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@druid.apache.org
For additional commands, e-mail: commits-help@druid.apache.org