Skip to main content

Service status API

This document describes the API endpoints to retrieve service status, cluster information for Apache Druid.

In this document, http://SERVICE_IP:SERVICE_PORT is a placeholder for the server address of deployment and the service port. For example, on the quickstart configuration, replace http://ROUTER_IP:ROUTER_PORT with http://localhost:8888.

Common

All services support the following endpoints.

You can use each endpoint with the ports for each type of service. The following table contains port addresses for a local configuration:

ServicePort address
Coordinator8081
Overlord8081
Router8888
Broker8082
Historical8083
MiddleManager8091

Get service information

Retrieves the Druid version, loaded extensions, memory used, total memory, and other useful information about the individual service.

Modify the host and port for the endpoint to match the service to query. Refer to the default service ports for the port numbers.

URL

GET /status

Responses


Successfully retrieved service information


Sample request

curl "http://ROUTER_IP:ROUTER_PORT/status"

Sample response

Click to show sample response
{
"version": "26.0.0",
"modules": [
{
"name": "org.apache.druid.common.aws.AWSModule",
"artifact": "druid-aws-common",
"version": "26.0.0"
},
{
"name": "org.apache.druid.common.gcp.GcpModule",
"artifact": "druid-gcp-common",
"version": "26.0.0"
},
{
"name": "org.apache.druid.storage.hdfs.HdfsStorageDruidModule",
"artifact": "druid-hdfs-storage",
"version": "26.0.0"
},
{
"name": "org.apache.druid.indexing.kafka.KafkaIndexTaskModule",
"artifact": "druid-kafka-indexing-service",
"version": "26.0.0"
},
{
"name": "org.apache.druid.query.aggregation.datasketches.theta.SketchModule",
"artifact": "druid-datasketches",
"version": "26.0.0"
},
{
"name": "org.apache.druid.query.aggregation.datasketches.theta.oldapi.OldApiSketchModule",
"artifact": "druid-datasketches",
"version": "26.0.0"
},
{
"name": "org.apache.druid.query.aggregation.datasketches.quantiles.DoublesSketchModule",
"artifact": "druid-datasketches",
"version": "26.0.0"
},
{
"name": "org.apache.druid.query.aggregation.datasketches.tuple.ArrayOfDoublesSketchModule",
"artifact": "druid-datasketches",
"version": "26.0.0"
},
{
"name": "org.apache.druid.query.aggregation.datasketches.hll.HllSketchModule",
"artifact": "druid-datasketches",
"version": "26.0.0"
},
{
"name": "org.apache.druid.query.aggregation.datasketches.kll.KllSketchModule",
"artifact": "druid-datasketches",
"version": "26.0.0"
},
{
"name": "org.apache.druid.msq.guice.MSQExternalDataSourceModule",
"artifact": "druid-multi-stage-query",
"version": "26.0.0"
},
{
"name": "org.apache.druid.msq.guice.MSQIndexingModule",
"artifact": "druid-multi-stage-query",
"version": "26.0.0"
},
{
"name": "org.apache.druid.msq.guice.MSQDurableStorageModule",
"artifact": "druid-multi-stage-query",
"version": "26.0.0"
},
{
"name": "org.apache.druid.msq.guice.MSQServiceClientModule",
"artifact": "druid-multi-stage-query",
"version": "26.0.0"
},
{
"name": "org.apache.druid.msq.guice.MSQSqlModule",
"artifact": "druid-multi-stage-query",
"version": "26.0.0"
},
{
"name": "org.apache.druid.msq.guice.SqlTaskModule",
"artifact": "druid-multi-stage-query",
"version": "26.0.0"
}
],
"memory": {
"maxMemory": 268435456,
"totalMemory": 268435456,
"freeMemory": 139060688,
"usedMemory": 129374768,
"directMemory": 134217728
}
}

Get service health

Retrieves the online status of the individual Druid service. It is a simple health check to determine if the service is running and accessible. If online, it will always return a boolean true value, indicating that the service can receive API calls. This endpoint is suitable for automated health checks.

Modify the host and port for the endpoint to match the service to query. Refer to the default service ports for the port numbers.

Additional checks for readiness should use the Historical segment readiness and Broker query readiness endpoints.

URL

GET /status/health

Responses


Successfully retrieved service health

Sample request

curl "http://ROUTER_IP:ROUTER_PORT/status/health"

Sample response

Click to show sample response
true

Get configuration properties

Retrieves the current configuration properties of the individual service queried.

Modify the host and port for the endpoint to match the service to query. Refer to the default service ports for the port numbers.

URL

GET /status/properties

Responses


Successfully retrieved service configuration properties

Sample request

curl "http://ROUTER_IP:ROUTER_PORT/status/properties"

Sample response

Click to show sample response
{
{
"gopherProxySet": "false",
"awt.toolkit": "sun.lwawt.macosx.LWCToolkit",
"druid.monitoring.monitors": "[\"org.apache.druid.java.util.metrics.JvmMonitor\"]",
"java.specification.version": "11",
"sun.cpu.isalist": "",
"druid.plaintextPort": "8888",
"sun.jnu.encoding": "UTF-8",
"druid.indexing.doubleStorage": "double",
"druid.metadata.storage.connector.port": "1527",
"java.class.path": "/Users/genericUserPath",
"log4j.shutdownHookEnabled": "true",
"java.vm.vendor": "Homebrew",
"sun.arch.data.model": "64",
"druid.extensions.loadList": "[\"druid-hdfs-storage\", \"druid-kafka-indexing-service\", \"druid-datasketches\", \"druid-multi-stage-query\"]",
"java.vendor.url": "https://github.com/Homebrew/homebrew-core/issues",
"druid.router.coordinatorServiceName": "druid/coordinator",
"user.timezone": "UTC",
"druid.global.http.eagerInitialization": "false",
"os.name": "Mac OS X",
"java.vm.specification.version": "11",
"sun.java.launcher": "SUN_STANDARD",
"user.country": "US",
"sun.boot.library.path": "/opt/homebrew/Cellar/openjdk@11/11.0.19/libexec/openjdk.jdk/Contents/Home/lib",
"sun.java.command": "org.apache.druid.cli.Main server router",
"http.nonProxyHosts": "local|*.local|169.254/16|*.169.254/16",
"jdk.debug": "release",
"druid.metadata.storage.connector.host": "localhost",
"sun.cpu.endian": "little",
"druid.zk.paths.base": "/druid",
"user.home": "/Users/genericUser",
"user.language": "en",
"java.specification.vendor": "Oracle Corporation",
"java.version.date": "2023-04-18",
"java.home": "/opt/homebrew/Cellar/openjdk@11/11.0.19/libexec/openjdk.jdk/Contents/Home",
"druid.service": "druid/router",
"druid.selectors.coordinator.serviceName": "druid/coordinator",
"druid.metadata.storage.connector.connectURI": "jdbc:derby://localhost:1527/var/druid/metadata.db;create=true",
"file.separator": "/",
"druid.selectors.indexing.serviceName": "druid/overlord",
"java.vm.compressedOopsMode": "Zero based",
"druid.metadata.storage.type": "derby",
"line.separator": "\n",
"druid.log.path": "/Users/genericUserPath",
"java.vm.specification.vendor": "Oracle Corporation",
"java.specification.name": "Java Platform API Specification",
"druid.indexer.logs.directory": "var/druid/indexing-logs",
"java.awt.graphicsenv": "sun.awt.CGraphicsEnvironment",
"druid.router.defaultBrokerServiceName": "druid/broker",
"druid.storage.storageDirectory": "var/druid/segments",
"sun.management.compiler": "HotSpot 64-Bit Tiered Compilers",
"ftp.nonProxyHosts": "local|*.local|169.254/16|*.169.254/16",
"java.runtime.version": "11.0.19+0",
"user.name": "genericUser",
"druid.indexer.logs.type": "file",
"druid.host": "localhost",
"log4j2.is.webapp": "false",
"path.separator": ":",
"os.version": "12.6.5",
"druid.lookup.enableLookupSyncOnStartup": "false",
"java.runtime.name": "OpenJDK Runtime Environment",
"druid.zk.service.host": "localhost",
"file.encoding": "UTF-8",
"druid.sql.planner.useGroupingSetForExactDistinct": "true",
"druid.router.managementProxy.enabled": "true",
"java.vm.name": "OpenJDK 64-Bit Server VM",
"java.vendor.version": "Homebrew",
"druid.startup.logging.logProperties": "true",
"java.vendor.url.bug": "https://github.com/Homebrew/homebrew-core/issues",
"log4j.shutdownCallbackRegistry": "org.apache.druid.common.config.Log4jShutdown",
"java.io.tmpdir": "var/tmp",
"druid.sql.enable": "true",
"druid.emitter.logging.logLevel": "info",
"java.version": "11.0.19",
"user.dir": "/Users/genericUser/Downloads/apache-druid-26.0.0",
"os.arch": "aarch64",
"java.vm.specification.name": "Java Virtual Machine Specification",
"druid.node.type": "router",
"java.awt.printerjob": "sun.lwawt.macosx.CPrinterJob",
"sun.os.patch.level": "unknown",
"java.util.logging.manager": "org.apache.logging.log4j.jul.LogManager",
"java.library.path": "/Users/genericUserPath",
"java.vendor": "Homebrew",
"java.vm.info": "mixed mode",
"java.vm.version": "11.0.19+0",
"druid.emitter": "noop",
"sun.io.unicode.encoding": "UnicodeBig",
"druid.storage.type": "local",
"druid.expressions.useStrictBooleans": "true",
"java.class.version": "55.0",
"socksNonProxyHosts": "local|*.local|169.254/16|*.169.254/16",
"druid.server.hiddenProperties": "[\"druid.s3.accessKey\",\"druid.s3.secretKey\",\"druid.metadata.storage.connector.password\", \"password\", \"key\", \"token\", \"pwd\"]"
}

Get node discovery status and cluster integration confirmation

Retrieves a JSON map of the form {"selfDiscovered": true/false}, indicating whether the node has received a confirmation from the central node discovery mechanism (currently ZooKeeper) of the Druid cluster that the node has been added to the cluster.

Only consider a Druid node "healthy" or "ready" in automated deployment/container management systems when this endpoint returns {"selfDiscovered": true}. Nodes experiencing network issues may become isolated and are not healthy. For nodes that use Zookeeper segment discovery, a response of {"selfDiscovered": true} indicates that the node's Zookeeper client has started receiving data from the Zookeeper cluster, enabling timely discovery of segments and other nodes.

URL

GET /status/selfDiscovered/status

Responses


Node was successfully added to the cluster

Sample request

curl "http://ROUTER_IP:ROUTER_PORT/status/selfDiscovered/status"

Sample response

Click to show sample response
{
"selfDiscovered": true
}

Get node self-discovery status

Returns an HTTP status code to indicate node discovery within the Druid cluster. This endpoint is similar to the status/selfDiscovered/status endpoint, but relies on HTTP status codes alone. Use this endpoint for monitoring checks that are unable to examine the response body. For example, AWS load balancer health checks.

URL

GET /status/selfDiscovered

Responses


Successfully retrieved node status

Sample request

curl "http://ROUTER_IP:ROUTER_PORT/status/selfDiscovered"

Sample response

A successful response to this endpoint results in an empty response body.

Coordinator

Get Coordinator leader address

Retrieves the address of the current leader Coordinator of the cluster. If any request is sent to a non-leader Coordinator, the request is automatically redirected to the leader Coordinator.

URL

GET /druid/coordinator/v1/leader

Responses


Successfully retrieved leader Coordinator address


Sample request

curl "http://ROUTER_IP:ROUTER_PORT/druid/coordinator/v1/leader"

Sample response

Click to show sample response
http://localhost:8081

Get Coordinator leader status

Retrieves a JSON object with a leader key. Returns true if this server is the current leader Coordinator of the cluster. To get the individual address of the leader Coordinator node, see the leader endpoint.

Use this endpoint as a load balancer status check when you only want the active leader to be considered in-service at the load balancer.

URL

GET /druid/coordinator/v1/isLeader

Responses


Current server is the leader


Sample request

curl "http://COORDINATOR_IP:COORDINATOR_PORT/druid/coordinator/v1/isLeader"

Sample response

Click to show sample response
{
"leader": true
}

Overlord

Get Overlord leader address

Retrieves the address of the current leader Overlord of the cluster. In a cluster of multiple Overlords, only one Overlord assumes the leading role, while the remaining Overlords remain on standby.

URL

GET /druid/indexer/v1/leader

Responses


Successfully retrieved leader Overlord address


Sample request

curl "http://ROUTER_IP:ROUTER_PORT/druid/indexer/v1/leader"

Sample response

Click to show sample response
http://localhost:8081

Get Overlord leader status

Retrieves a JSON object with a leader property. The value can be true or false, indicating if this server is the current leader Overlord of the cluster. To get the individual address of the leader Overlord node, see the leader endpoint.

Use this endpoint as a load balancer status check when you only want the active leader to be considered in-service at the load balancer.

URL

GET /druid/indexer/v1/isLeader

Responses


Current server is the leader


Sample request

curl "http://OVERLORD_IP:OVERLORD_PORT/druid/indexer/v1/isLeader"

Sample response

Click to show sample response
{
"leader": true
}

MiddleManager

Get MiddleManager state status

Retrieves the enabled state of the MiddleManager. Returns JSON object keyed by the combined druid.host and druid.port with a boolean true or false state as the value.

URL

GET /druid/worker/v1/enabled

Responses


Successfully retrieved MiddleManager state


Sample request

curl "http://MIDDLEMANAGER_IP:MIDDLEMANAGER_PORT/druid/worker/v1/enabled"

Sample response

Click to show sample response
{
"localhost:8091": true
}

Get active tasks

Retrieves a list of active tasks being run on MiddleManager. Returns JSON list of task ID strings. Note that for normal usage, you should use the /druid/indexer/v1/tasks Tasks API endpoint or one of the task state specific variants instead.

URL

GET /druid/worker/v1/tasks

Responses


Successfully retrieved active tasks


Sample request

curl "http://MIDDLEMANAGER_IP:MIDDLEMANAGER_PORT/druid/worker/v1/tasks"

Sample response

Click to show sample response
[
"index_parallel_wikipedia_mgchefio_2023-06-13T22:18:05.360Z"
]

Get task log

Retrieves task log output stream by task ID. For normal usage, you should use the /druid/indexer/v1/task/{taskId}/log Tasks API endpoint instead.

URL

GET /druid/worker/v1/task/:taskId/log

Shut down running task

Shuts down a running task by ID. For normal usage, you should use the /druid/indexer/v1/task/:taskId/shutdown Tasks API endpoint instead.

URL

POST /druid/worker/v1/task/:taskId/shutdown

Responses


Successfully shut down a task


Sample request

The following example shuts down a task with specified ID index_kafka_wikiticker_f7011f8ffba384b_fpeclode.

curl "http://MIDDLEMANAGER_IP:MIDDLEMANAGER_PORT/druid/worker/v1/task/index_kafka_wikiticker_f7011f8ffba384b_fpeclode/shutdown"

Sample response

Click to show sample response
{
"task":"index_kafka_wikiticker_f7011f8ffba384b_fpeclode"
}

Disable MiddleManager

Disables a MiddleManager, causing it to stop accepting new tasks but complete all existing tasks. Returns a JSON object keyed by the combined druid.host and druid.port.

URL

POST /druid/worker/v1/disable

Responses


Successfully disabled MiddleManager

Sample request

curl "http://MIDDLEMANAGER_IP:MIDDLEMANAGER_PORT/druid/worker/v1/disable"

Sample response

Click to show sample response
{
"localhost:8091":"disabled"
}

Enable MiddleManager

Enables a MiddleManager, allowing it to accept new tasks again if it was previously disabled. Returns a JSON object keyed by the combined druid.host and druid.port.

URL

POST /druid/worker/v1/enable

Responses


Successfully enabled MiddleManager

Sample request

curl "http://MIDDLEMANAGER_IP:MIDDLEMANAGER_PORT/druid/worker/v1/enable"

Sample response

Click to show sample response
{
"localhost:8091":"enabled"
}

Historical

Get segment load status

Retrieves a JSON object of the form {"cacheInitialized":value}, where value is either true or false indicating if all segments in the local cache have been loaded.

Use this endpoint to know when a Broker service is ready to accept queries after a restart.

URL

GET /druid/historical/v1/loadstatus

Responses


Successfully retrieved status

Sample request

curl "http://HISTORICAL_IP:HISTORICAL_PORT/druid/historical/v1/loadstatus"

Sample response

Click to show sample response
{
"cacheInitialized": true
}

Get segment readiness

Retrieves a status code to indicate if all segments in the local cache have been loaded. Similar to /druid/historical/v1/loadstatus, but instead of returning JSON with a flag, it returns status codes.

URL

GET /druid/historical/v1/readiness

Responses


Segments in local cache successfully loaded

Sample request

curl "http://HISTORICAL_IP:HISTORICAL_PORT/druid/historical/v1/readiness"

Sample response

A successful response to this endpoint results in an empty response body.

Load Status

Get Broker query load status

Retrieves a flag indicating if the Broker knows about all segments in the cluster. Use this endpoint to know when a Broker service is ready to accept queries after a restart.

URL

GET /druid/broker/v1/loadstatus

Responses


Segments successfully loaded

Sample request

curl "http://BROKER_IP:BROKER_PORT/druid/broker/v1/loadstatus"

Sample response

Click to show sample response
{
"inventoryInitialized": true
}

Get Broker query readiness

Retrieves a status code to indicate Broker readiness. Readiness signifies the Broker knows about all segments in the cluster and is ready to accept queries after a restart. Similar to /druid/broker/v1/loadstatus, but instead of returning a JSON, it returns status codes.

URL

GET /druid/broker/v1/readiness

Responses


Segments successfully loaded

Sample request

curl "http://BROKER_IP:BROKER_PORT/druid/broker/v1/readiness"

Sample response

A successful response to this endpoint results in an empty response body.