serviceUrl(String serviceUrl) {
/**
* Sets the topic to consumer from. This is required.
*
- * Topic names (https://pulsar.incubator.apache.org/docs/latest/getting-started/ConceptsAndArchitecture/#Topics)
+ *
Topic names (https://pulsar.apache.org/docs/latest/getting-started/ConceptsAndArchitecture/#Topics)
* are in the following format:
* {persistent|non-persistent}://tenant/namespace/topic
*
diff --git a/pulsar-functions/instance/src/main/java/org/apache/pulsar/functions/instance/FunctionResultRouter.java b/pulsar-functions/instance/src/main/java/org/apache/pulsar/functions/instance/FunctionResultRouter.java
index adeb46b3c8947..be06ee3aea270 100644
--- a/pulsar-functions/instance/src/main/java/org/apache/pulsar/functions/instance/FunctionResultRouter.java
+++ b/pulsar-functions/instance/src/main/java/org/apache/pulsar/functions/instance/FunctionResultRouter.java
@@ -59,7 +59,7 @@ public int choosePartition(Message msg, TopicMetadata metadata) {
// round-robin routing.
if (msg.hasKey() || msg.getSequenceId() < 0) {
// TODO: the message key routing is problematic at this moment.
- // https://github.com/apache/incubator-pulsar/pull/1029 is fixing that.
+ // https://github.com/apache/pulsar/pull/1029 is fixing that.
return super.choosePartition(msg, metadata);
}
// if there is no key and sequence id is provided, it is an effectively-once publish, we need to ensure
diff --git a/pulsar-io/hdfs/src/test/java/org/apache/pulsar/io/hdfs/sink/AbstractHdfsSinkTest.java b/pulsar-io/hdfs/src/test/java/org/apache/pulsar/io/hdfs/sink/AbstractHdfsSinkTest.java
index 32085dd5dc6e5..5d40138d61e99 100644
--- a/pulsar-io/hdfs/src/test/java/org/apache/pulsar/io/hdfs/sink/AbstractHdfsSinkTest.java
+++ b/pulsar-io/hdfs/src/test/java/org/apache/pulsar/io/hdfs/sink/AbstractHdfsSinkTest.java
@@ -53,8 +53,8 @@ public abstract class AbstractHdfsSinkTest {
@BeforeMethod
public final void setUp() throws Exception {
map = new HashMap ();
- map.put("hdfsConfigResources", "../incubator-pulsar/pulsar-io/hdfs/src/test/resources/hadoop/core-site.xml,"
- + "../incubator-pulsar/pulsar-io/hdfs/src/test/resources/hadoop/hdfs-site.xml");
+ map.put("hdfsConfigResources", "../pulsar/pulsar-io/hdfs/src/test/resources/hadoop/core-site.xml,"
+ + "../pulsar/pulsar-io/hdfs/src/test/resources/hadoop/hdfs-site.xml");
map.put("directory", "/tmp/testing");
map.put("filenamePrefix", "prefix");
diff --git a/site2/README.md b/site2/README.md
index 8003f15c13e31..fa8c705d9b614 100644
--- a/site2/README.md
+++ b/site2/README.md
@@ -211,4 +211,4 @@ to start contributing.
Your contributed translations will be licensed under [Apache License V2](https://www.apache.org/licenses/LICENSE-2.0).
Pulsar Committers will review those translations. If your translations are not reviewed or approved by any committers,
-feel free to reach out to use via [slack channel](https://apache-pulsar.herokuapp.com/) or [mailing lists](https://pulsar.incubator.apache.org/contact/).
+feel free to reach out to use via [slack channel](https://apache-pulsar.herokuapp.com/) or [mailing lists](https://pulsar.apache.org/contact/).
diff --git a/site2/docs/adaptors-kafka.md b/site2/docs/adaptors-kafka.md
index 809eae3f56c0e..36aa224eab717 100644
--- a/site2/docs/adaptors-kafka.md
+++ b/site2/docs/adaptors-kafka.md
@@ -104,7 +104,7 @@ while (true) {
## Complete Examples
You can find the complete producer and consumer examples
-[here](https://github.com/apache/incubator-pulsar/tree/master/pulsar-client-kafka-compat/pulsar-client-kafka-tests/src/test/java/org/apache/pulsar/client/kafka/compat/examples).
+[here](https://github.com/apache/pulsar/tree/master/pulsar-client-kafka-compat/pulsar-client-kafka-tests/src/test/java/org/apache/pulsar/client/kafka/compat/examples).
## Compatibility matrix
diff --git a/site2/docs/adaptors-spark.md b/site2/docs/adaptors-spark.md
index bb92db121f88a..2539840802faa 100644
--- a/site2/docs/adaptors-spark.md
+++ b/site2/docs/adaptors-spark.md
@@ -61,6 +61,6 @@ JavaReceiverInputDStream msgs = jssc
## Example
-You can find a complete example [here](https://github.com/apache/incubator-pulsar/tree/master/pulsar-spark/src/test/java/org/apache/pulsar/spark/example/SparkStreamingPulsarReceiverExample.java).
+You can find a complete example [here](https://github.com/apache/pulsar/tree/master/pulsar-spark/src/test/java/org/apache/pulsar/spark/example/SparkStreamingPulsarReceiverExample.java).
In this example, the number of messages which contain the string "Pulsar" in received messages is counted.
diff --git a/site2/docs/adaptors-storm.md b/site2/docs/adaptors-storm.md
index 2c4e795c4d2af..1f4d7f5960b36 100644
--- a/site2/docs/adaptors-storm.md
+++ b/site2/docs/adaptors-storm.md
@@ -101,4 +101,4 @@ PulsarBolt bolt = new PulsarBolt(boltConf, clientConf);
## Example
-You can find a complete example [here](https://github.com/apache/incubator-pulsar/tree/master/pulsar-storm/src/test/java/org/apache/pulsar/storm/example/StormExample.java).
+You can find a complete example [here](https://github.com/apache/pulsar/tree/master/pulsar-storm/src/test/java/org/apache/pulsar/storm/example/StormExample.java).
diff --git a/site2/docs/client-libraries-cpp.md b/site2/docs/client-libraries-cpp.md
index 864efdd2fef88..fdc8e6b0736c9 100644
--- a/site2/docs/client-libraries-cpp.md
+++ b/site2/docs/client-libraries-cpp.md
@@ -94,7 +94,7 @@ Use the [Homebrew](https://brew.sh/) supplied recipe to build the Pulsar
client lib on MacOS.
```shell
-brew install https://raw.githubusercontent.com/apache/incubator-pulsar/master/pulsar-client-cpp/homebrew/libpulsar.rb
+brew install https://raw.githubusercontent.com/apache/pulsar/master/pulsar-client-cpp/homebrew/libpulsar.rb
```
If using Python 3 on MacOS, add the flag `--with-python3` to the above command.
diff --git a/site2/docs/client-libraries-go.md b/site2/docs/client-libraries-go.md
index 421d45797b532..d9defdc5d2f0d 100644
--- a/site2/docs/client-libraries-go.md
+++ b/site2/docs/client-libraries-go.md
@@ -7,7 +7,7 @@ sidebar_label: Go
The Pulsar Go client can be used to create Pulsar [producers](#producers), [consumers](#consumers), and [readers](#readers) in Go (aka Golang).
> #### API docs available as well
-> For standard API docs, consult the [Godoc](https://godoc.org/github.com/apache/incubator-pulsar/pulsar-client-go/pulsar).
+> For standard API docs, consult the [Godoc](https://godoc.org/github.com/apache/pulsar/pulsar-client-go/pulsar).
## Installation
@@ -28,19 +28,19 @@ You can install the `pulsar` library locally using `go get`:
> from latest master. You need to make sure you have installed the right pulsar cpp client library.
```bash
-$ go get -u github.com/apache/incubator-pulsar/pulsar-client-go/pulsar
+$ go get -u github.com/apache/pulsar/pulsar-client-go/pulsar
```
Or you can use [dep](https://github.com/golang/dep) for managing the dependencies.
```bash
-$ dep ensure -add github.com/apache/incubator-pulsar/pulsar-client-go/pulsar@v{{pulsar:version}}
+$ dep ensure -add github.com/apache/pulsar/pulsar-client-go/pulsar@v{{pulsar:version}}
```
Once installed locally, you can import it into your project:
```go
-import "github.com/apache/incubator-pulsar/pulsar-client-go/pulsar"
+import "github.com/apache/pulsar/pulsar-client-go/pulsar"
```
## Connection URLs
@@ -75,7 +75,7 @@ import (
"log"
"runtime"
- "github.com/apache/incubator-pulsar/pulsar-client-go/pulsar"
+ "github.com/apache/pulsar/pulsar-client-go/pulsar"
)
func main() {
@@ -153,7 +153,7 @@ import (
"context"
"fmt"
- "github.com/apache/incubator-pulsar/pulsar-client-go/pulsar"
+ "github.com/apache/pulsar/pulsar-client-go/pulsar"
)
func main() {
@@ -276,7 +276,7 @@ import (
"context"
"log"
- "github.com/apache/incubator-pulsar/pulsar-client-go/pulsar"
+ "github.com/apache/pulsar/pulsar-client-go/pulsar"
)
func main() {
@@ -359,7 +359,7 @@ import (
"context"
"log"
- "github.com/apache/incubator-pulsar/pulsar-client-go/pulsar"
+ "github.com/apache/pulsar/pulsar-client-go/pulsar"
)
func main() {
diff --git a/site2/docs/client-libraries-python.md b/site2/docs/client-libraries-python.md
index 5c593f99f1f9b..2c9fb63bfed8a 100644
--- a/site2/docs/client-libraries-python.md
+++ b/site2/docs/client-libraries-python.md
@@ -4,7 +4,7 @@ title: The Pulsar Python client
sidebar_label: Python
---
-The Pulsar Python client library is a wrapper over the existing [C++ client library](client-libraries-cpp.md) and exposes all of the [same features](/api/cpp). You can find the code in the [`python` subdirectory](https://github.com/apache/incubator-pulsar/tree/master/pulsar-client-cpp/python) of the C++ client code.
+The Pulsar Python client library is a wrapper over the existing [C++ client library](client-libraries-cpp.md) and exposes all of the [same features](/api/cpp). You can find the code in the [`python` subdirectory](https://github.com/apache/pulsar/tree/master/pulsar-client-cpp/python) of the C++ client code.
## Installation
diff --git a/site2/docs/client-libraries-websocket.md b/site2/docs/client-libraries-websocket.md
index 794f9da4196c0..d0b1dbd3b06b8 100644
--- a/site2/docs/client-libraries-websocket.md
+++ b/site2/docs/client-libraries-websocket.md
@@ -73,8 +73,8 @@ Key | Type | Required? | Explanation
`batchingMaxMessages` | int | no | Maximum number of messages permitted in a batch (default: 1000)
`maxPendingMessages` | int | no | Set the max size of the internal-queue holding the messages (default: 1000)
`batchingMaxPublishDelay` | long | no | Time period within which the messages will be batched (default: 10ms)
-`messageRoutingMode` | string | no | Message [routing mode](https://pulsar.incubator.apache.org/api/client/index.html?org/apache/pulsar/client/api/ProducerConfiguration.MessageRoutingMode.html) for the partitioned producer: `SinglePartition`, `RoundRobinPartition`
-`compressionType` | string | no | Compression [type](https://pulsar.incubator.apache.org/api/client/index.html?org/apache/pulsar/client/api/CompressionType.html): `LZ4`, `ZLIB`
+`messageRoutingMode` | string | no | Message [routing mode](https://pulsar.apache.org/api/client/index.html?org/apache/pulsar/client/api/ProducerConfiguration.MessageRoutingMode.html) for the partitioned producer: `SinglePartition`, `RoundRobinPartition`
+`compressionType` | string | no | Compression [type](https://pulsar.apache.org/api/client/index.html?org/apache/pulsar/client/api/CompressionType.html): `LZ4`, `ZLIB`
`producerName` | string | no | Specify the name for the producer. Pulsar will enforce only one producer with same name can be publishing on a topic
`initialSequenceId` | long | no | Set the baseline for the sequence ids for messages published by the producer.
`hashingScheme` | string | no | [Hashing function](http://pulsar.apache.org/api/client/org/apache/pulsar/client/api/ProducerConfiguration.HashingScheme.html) to use when publishing on a partitioned topic: `JavaStringHash`, `Murmur3_32Hash`
@@ -138,7 +138,7 @@ ws://broker-service-url:8080/ws/v2/consumer/persistent/:tenant/:namespace/:topic
Key | Type | Required? | Explanation
:---|:-----|:----------|:-----------
`ackTimeoutMillis` | long | no | Set the timeout for unacked messages (default: 0)
-`subscriptionType` | string | no | [Subscription type](https://pulsar.incubator.apache.org/api/client/index.html?org/apache/pulsar/client/api/SubscriptionType.html): `Exclusive`, `Failover`, `Shared`
+`subscriptionType` | string | no | [Subscription type](https://pulsar.apache.org/api/client/index.html?org/apache/pulsar/client/api/SubscriptionType.html): `Exclusive`, `Failover`, `Shared`
`receiverQueueSize` | int | no | Size of the consumer receive queue (default: 1000)
`consumerName` | string | no | Consumer name
`priorityLevel` | int | no | Define a [priority](http://pulsar.apache.org/api/client/org/apache/pulsar/client/api/ConsumerConfiguration.html#setPriorityLevel-int-) for the consumer
diff --git a/site2/docs/deploy-aws.md b/site2/docs/deploy-aws.md
index 5f3de01bc64c6..ab3328573bfa0 100644
--- a/site2/docs/deploy-aws.md
+++ b/site2/docs/deploy-aws.md
@@ -32,11 +32,11 @@ $ pip install ansible
You can install Terraform using the instructions [here](https://www.terraform.io/intro/getting-started/install.html).
-You'll also need to have the Terraform and Ansible configurations for Pulsar locally on your machine. They're contained in Pulsar's [GitHub repository](https://github.com/apache/incubator-pulsar), which you can fetch using Git:
+You'll also need to have the Terraform and Ansible configurations for Pulsar locally on your machine. They're contained in Pulsar's [GitHub repository](https://github.com/apache/pulsar), which you can fetch using Git:
```bash
-$ git clone https://github.com/apache/incubator-pulsar
-$ cd incubator-pulsar/deployment/terraform-ansible/aws
+$ git clone https://github.com/apache/pulsar
+$ cd pulsar/deployment/terraform-ansible/aws
```
## SSH setup
diff --git a/site2/docs/deploy-bare-metal-multi-cluster.md b/site2/docs/deploy-bare-metal-multi-cluster.md
index 5614d14aa88cb..631818183d206 100644
--- a/site2/docs/deploy-bare-metal-multi-cluster.md
+++ b/site2/docs/deploy-bare-metal-multi-cluster.md
@@ -38,11 +38,11 @@ To get started running Pulsar, download a binary tarball release in one of the f
* Pulsar {{pulsar:version}} binary release
* from the Pulsar [downloads page](pulsar:download_page_url)
-* from the Pulsar [releases page](https://github.com/apache/incubator-pulsar/releases/latest)
+* from the Pulsar [releases page](https://github.com/apache/pulsar/releases/latest)
* using [wget](https://www.gnu.org/software/wget):
```shell
- $ wget 'https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=incubator/pulsar/pulsar-{{pulsar:version}}/apache-pulsar-{{pulsar:version}}-bin.tar.gz' -O apache-pulsar-{{pulsar:version}}-bin.tar.gz
+ $ wget 'https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=pulsar/pulsar-{{pulsar:version}}/apache-pulsar-{{pulsar:version}}-bin.tar.gz' -O apache-pulsar-{{pulsar:version}}-bin.tar.gz
```
Once the tarball is downloaded, untar it and `cd` into the resulting directory:
diff --git a/site2/docs/deploy-bare-metal.md b/site2/docs/deploy-bare-metal.md
index a438f9214ac80..72e3e4e564f4c 100644
--- a/site2/docs/deploy-bare-metal.md
+++ b/site2/docs/deploy-bare-metal.md
@@ -68,7 +68,7 @@ To get started deploying a Pulsar cluster on bare metal, you'll need to download
* By clicking on the link directly below, which will automatically trigger a download:
* Pulsar {{pulsar:version}} binary release
* From the Pulsar [downloads page](pulsar:download_page_url)
-* From the Pulsar [releases page](https://github.com/apache/incubator-pulsar/releases/latest) on [GitHub](https://github.com)
+* From the Pulsar [releases page](https://github.com/apache/pulsar/releases/latest) on [GitHub](https://github.com)
* Using [wget](https://www.gnu.org/software/wget):
```bash
@@ -106,7 +106,7 @@ one of the following ways:
* Pulsar IO Connectors {{pulsar:version}} release
* from the Pulsar [downloads page](pulsar:download_page_url)
-* from the Pulsar [releases page](https://github.com/apache/incubator-pulsar/releases/latest)
+* from the Pulsar [releases page](https://github.com/apache/pulsar/releases/latest)
* using [wget](https://www.gnu.org/software/wget):
```shell
diff --git a/site2/docs/deploy-dcos.md b/site2/docs/deploy-dcos.md
index 5f669390853ee..d608cbc0f1683 100644
--- a/site2/docs/deploy-dcos.md
+++ b/site2/docs/deploy-dcos.md
@@ -20,10 +20,10 @@ In order to run Pulsar on DC/OS, you will need the following:
* DC/OS version [1.9](https://docs.mesosphere.com/1.9/) or higher
* A [DC/OS cluster](https://docs.mesosphere.com/1.9/installing/) with at least three agent nodes
* The [DC/OS CLI tool](https://docs.mesosphere.com/1.9/cli/install/) installed
-* The [`PulsarGroups.json`](https://github.com/apache/incubator-pulsar/blob/master/deployment/dcos/PulsarGroups.json) configuration file from the Pulsar GitHub repo.
+* The [`PulsarGroups.json`](https://github.com/apache/pulsar/blob/master/deployment/dcos/PulsarGroups.json) configuration file from the Pulsar GitHub repo.
```bash
- $ curl -O https://raw.githubusercontent.com/apache/incubator-pulsar/master/deployment/dcos/PulsarGroups.json
+ $ curl -O https://raw.githubusercontent.com/apache/pulsar/master/deployment/dcos/PulsarGroups.json
```
Each node in the DC/OS-managed Mesos cluster must have at least:
diff --git a/site2/docs/developing-binary-protocol.md b/site2/docs/developing-binary-protocol.md
index d3b46c1289da6..f2966f574eae1 100644
--- a/site2/docs/developing-binary-protocol.md
+++ b/site2/docs/developing-binary-protocol.md
@@ -6,7 +6,7 @@ sidebar_label: Binary protocol
Pulsar uses a custom binary protocol for communications between producers/consumers and brokers. This protocol is designed to support required features, such as acknowledgements and flow control, while ensuring maximum transport and implementation efficiency.
-Clients and brokers exchange *commands* with each other. Commands are formatted as binary [protocol buffer](https://developers.google.com/protocol-buffers/) (aka *protobuf*) messages. The format of protobuf commands is specified in the [`PulsarApi.proto`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-common/src/main/proto/PulsarApi.proto) file and also documented in the [Protobuf interface](#protobuf-interface) section below.
+Clients and brokers exchange *commands* with each other. Commands are formatted as binary [protocol buffer](https://developers.google.com/protocol-buffers/) (aka *protobuf*) messages. The format of protobuf commands is specified in the [`PulsarApi.proto`](https://github.com/apache/pulsar/blob/master/pulsar-common/src/main/proto/PulsarApi.proto) file and also documented in the [Protobuf interface](#protobuf-interface) section below.
> ### Connection sharing
> Commands for different producers and consumers can be interleaved and sent through the same connection without restriction.
@@ -59,7 +59,7 @@ Message metadata is stored alongside the application-specified payload as a seri
| `producer_name` | The name of the producer that published the message |
| `sequence_id` | The sequence ID of the message, assigned by producer} |
| `publish_time` | The publish timestamp in Unix time (i.e. as the number of milliseconds since January 1st, 1970 in UTC) |
-| `properties` | A sequence of key/value pairs (using the [`KeyValue`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-common/src/main/proto/PulsarApi.proto#L32) message). These are application-defined keys and values with no special meaning to Pulsar. |
+| `properties` | A sequence of key/value pairs (using the [`KeyValue`](https://github.com/apache/pulsar/blob/master/pulsar-common/src/main/proto/PulsarApi.proto#L32) message). These are application-defined keys and values with no special meaning to Pulsar. |
| `replicated_from` *(optional)* | Indicates that the message has been replicated and specifies the name of the [cluster](reference-terminology.md#cluster) where the message was originally published |
| `partition_key` *(optional)* | While publishing on a partition topic, if the key is present, the hash of the key is used to determine which partition to choose |
| `compression` *(optional)* | Signals that payload has been compressed and with which compression library |
diff --git a/site2/docs/developing-cpp.md b/site2/docs/developing-cpp.md
index 47bbb37b8e41d..2387f24ea660d 100644
--- a/site2/docs/developing-cpp.md
+++ b/site2/docs/developing-cpp.md
@@ -25,7 +25,7 @@ You need to have the following installed to use the C++ client:
There are separate compilation instructions for [MacOS](#macos) and [Linux](#linux). For both systems, start by cloning the Pulsar repository:
```shell
-$ git clone https://github.com/apache/incubator-pulsar
+$ git clone https://github.com/apache/pulsar
```
### Linux
diff --git a/site2/docs/developing-load-manager.md b/site2/docs/developing-load-manager.md
index f545e5afa9794..1e2fcfe077fe8 100644
--- a/site2/docs/developing-load-manager.md
+++ b/site2/docs/developing-load-manager.md
@@ -4,7 +4,7 @@ title: Modular load manager
sidebar_label: Modular load manager
---
-The *modular load manager*, implemented in [`ModularLoadManagerImpl`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/impl/ModularLoadManagerImpl.java), is a flexible alternative to the previously implemented load manager, [`SimpleLoadManagerImpl`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/impl/SimpleLoadManagerImpl.java), which attempts to simplify how load is managed while also providing abstractions so that complex load management strategies may be implemented.
+The *modular load manager*, implemented in [`ModularLoadManagerImpl`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/impl/ModularLoadManagerImpl.java), is a flexible alternative to the previously implemented load manager, [`SimpleLoadManagerImpl`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/impl/SimpleLoadManagerImpl.java), which attempts to simplify how load is managed while also providing abstractions so that complex load management strategies may be implemented.
## Usage
@@ -131,17 +131,17 @@ It is important to note that the module load manager is _centralized_, meaning t
### Data
-The data monitored by the modular load manager is contained in the [`LoadData`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/LoadData.java) class.
+The data monitored by the modular load manager is contained in the [`LoadData`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/LoadData.java) class.
Here, the available data is subdivided into the bundle data and the broker data.
#### Broker
-The broker data is contained in the [`BrokerData`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/BrokerData.java) class. It is further subdivided into two parts,
+The broker data is contained in the [`BrokerData`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/BrokerData.java) class. It is further subdivided into two parts,
one being the local data which every broker individually writes to ZooKeeper, and the other being the historical broker
data which is written to ZooKeeper by the leader broker.
##### Local Broker Data
-The local broker data is contained in the class [`LocalBrokerData`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-common/src/main/java/org/apache/pulsar/policies/data/loadbalancer/LocalBrokerData.java) and provides information about the following resources:
+The local broker data is contained in the class [`LocalBrokerData`](https://github.com/apache/pulsar/blob/master/pulsar-common/src/main/java/org/apache/pulsar/policies/data/loadbalancer/LocalBrokerData.java) and provides information about the following resources:
* CPU usage
* JVM heap memory usage
@@ -159,7 +159,7 @@ receive the update immediately via a ZooKeeper watch, where the local data is re
##### Historical Broker Data
-The historical broker data is contained in the [`TimeAverageBrokerData`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/TimeAverageBrokerData.java) class.
+The historical broker data is contained in the [`TimeAverageBrokerData`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/TimeAverageBrokerData.java) class.
In order to reconcile the need to make good decisions in a steady-state scenario and make reactive decisions in a critical scenario, the historical data is split into two parts: the short-term data for reactive decisions, and the long-term data for steady-state decisions. Both time frames maintain the following information:
@@ -172,7 +172,7 @@ The historical broker data is updated for each broker in memory by the leader br
##### Bundle Data
-The bundle data is contained in the [`BundleData`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/BundleData.java). Like the historical broker data, the bundle data is split into a short-term and a long-term time frame. The information maintained in each time frame:
+The bundle data is contained in the [`BundleData`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/BundleData.java). Like the historical broker data, the bundle data is split into a short-term and a long-term time frame. The information maintained in each time frame:
* Message rate in/out for this bundle
* Message Throughput In/Out for this bundle
@@ -195,7 +195,7 @@ broker data, according to the configuration `loadBalancerResourceQuotaUpdateInte
### Traffic Distribution
-The modular load manager uses the abstraction provided by [`ModularLoadManagerStrategy`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/ModularLoadManagerStrategy.java) to make decisions about bundle assignment. The strategy makes a decision by considering the service configuration, the entire load data, and the bundle data for the bundle to be assigned. Currently, the only supported strategy is [`LeastLongTermMessageRate`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/impl/LeastLongTermMessageRate.java), though soon users will have the ability to inject their own strategies if desired.
+The modular load manager uses the abstraction provided by [`ModularLoadManagerStrategy`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/ModularLoadManagerStrategy.java) to make decisions about bundle assignment. The strategy makes a decision by considering the service configuration, the entire load data, and the bundle data for the bundle to be assigned. Currently, the only supported strategy is [`LeastLongTermMessageRate`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/loadbalance/impl/LeastLongTermMessageRate.java), though soon users will have the ability to inject their own strategies if desired.
#### Least Long Term Message Rate Strategy
diff --git a/site2/docs/developing-schema.md b/site2/docs/developing-schema.md
index 2e3133e852e1a..6af03e89e9084 100644
--- a/site2/docs/developing-schema.md
+++ b/site2/docs/developing-schema.md
@@ -34,7 +34,7 @@ public interface SchemaStorage {
}
```
-> For a full-fledged example schema storage implementation, see the [`BookKeeperSchemaStorage`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/service/schema/BookkeeperSchemaStorage.java) class.
+> For a full-fledged example schema storage implementation, see the [`BookKeeperSchemaStorage`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/service/schema/BookkeeperSchemaStorage.java) class.
## SchemaStorageFactory interface
@@ -45,7 +45,7 @@ public interface SchemaStorageFactory {
}
```
-> For a full-fledged example schema storage factory implementation, see the [`BookKeeperSchemaStorageFactory`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/service/schema/BookkeeperSchemaStorageFactory.java) class.
+> For a full-fledged example schema storage factory implementation, see the [`BookKeeperSchemaStorageFactory`](https://github.com/apache/pulsar/blob/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/service/schema/BookkeeperSchemaStorageFactory.java) class.
## Deployment
diff --git a/site2/docs/functions-api.md b/site2/docs/functions-api.md
index 283fcd469d0e2..adec1e649a342 100644
--- a/site2/docs/functions-api.md
+++ b/site2/docs/functions-api.md
@@ -173,7 +173,7 @@ How you get started writing Pulsar Functions in Java depends on which API you're
org.apache.pulsar
pulsar-functions-api
- 2.0.0-incubating-SNAPSHOT
+ 2.1.1-incubating
```
@@ -181,7 +181,7 @@ How you get started writing Pulsar Functions in Java depends on which API you're
```groovy
dependencies {
- compile group: 'org.apache.pulsar', name: 'pulsar-functions-api', version: '2.0.0-incubating-SNAPSHOT'
+ compile group: 'org.apache.pulsar', name: 'pulsar-functions-api', version: '2.1.1-incubating'
}
```
@@ -236,14 +236,14 @@ There are several example Java SDK functions in this {@inject: github:folder:/pu
Function name | Description
:-------------|:-----------
-[`ContextFunction`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/ContextFunction.java) | Illustrates [context](#context)-specific functionality like [logging](#java-logging) and [metrics](#java-metrics)
-[`WordCountFunction`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/WordCountFunction.java) | Illustrates usage of Pulsar Function [state-storage](functions-overview.md#state-storage)
-[`ExclamationFunction`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/ExclamationFunction.java) | A basic string manipulation function for the Java SDK
-[`LoggingFunction`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/LoggingFunction.java) | A function that shows how [logging](#java-logging) works for Java
-[`PublishFunction`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/PublishFunction.java) | Publishes results to a topic specified in the function's [user config](#java-user-config) (rather than on the function's output topic)
-[`UserConfigFunction`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/UserConfigFunction.java) | A function that consumes [user-supplied configuration](#java-user-config) values
-[`UserMetricFunction`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/UserMetricFunction.java) | A function that records metrics
-[`VoidFunction`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/UserMetricFunction.java) | A simple [void function](#void-functions)
+[`ContextFunction`](https://github.com/apache/pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/ContextFunction.java) | Illustrates [context](#context)-specific functionality like [logging](#java-logging) and [metrics](#java-metrics)
+[`WordCountFunction`](https://github.com/apache/pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/WordCountFunction.java) | Illustrates usage of Pulsar Function [state-storage](functions-overview.md#state-storage)
+[`ExclamationFunction`](https://github.com/apache/pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/ExclamationFunction.java) | A basic string manipulation function for the Java SDK
+[`LoggingFunction`](https://github.com/apache/pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/LoggingFunction.java) | A function that shows how [logging](#java-logging) works for Java
+[`PublishFunction`](https://github.com/apache/pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/PublishFunction.java) | Publishes results to a topic specified in the function's [user config](#java-user-config) (rather than on the function's output topic)
+[`UserConfigFunction`](https://github.com/apache/pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/UserConfigFunction.java) | A function that consumes [user-supplied configuration](#java-user-config) values
+[`UserMetricFunction`](https://github.com/apache/pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/UserMetricFunction.java) | A function that records metrics
+[`VoidFunction`](https://github.com/apache/pulsar/blob/master/pulsar-functions/java-examples/src/main/java/org/apache/pulsar/functions/api/examples/UserMetricFunction.java) | A simple [void function](#void-functions)
### Java context object
@@ -561,13 +561,13 @@ There are several example Python functions in this {@inject: github:folder:/puls
Function file | Description
:-------------|:-----------
-[`exclamation_function.py`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/python-examples/exclamation_function.py) | Adds an exclamation point at the end of each incoming string
-[`logging_function.py`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/python-examples/logging_function.py) | Logs each incoming message
-[`thumbnailer.py`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-functions/python-examples/thumbnailer.py) | Takes image data as input and outputs a 128x128 thumbnail of each image
+[`exclamation_function.py`](https://github.com/apache/pulsar/blob/master/pulsar-functions/python-examples/exclamation_function.py) | Adds an exclamation point at the end of each incoming string
+[`logging_function.py`](https://github.com/apache/pulsar/blob/master/pulsar-functions/python-examples/logging_function.py) | Logs each incoming message
+[`thumbnailer.py`](https://github.com/apache/pulsar/blob/master/pulsar-functions/python-examples/thumbnailer.py) | Takes image data as input and outputs a 128x128 thumbnail of each image
#### Python context object
-The [`Context`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/context.py) class provides a number of methods that you can use to access the function's [context](#context). The various methods for the `Context` class are listed below:
+The [`Context`](https://github.com/apache/pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/context.py) class provides a number of methods that you can use to access the function's [context](#context). The various methods for the `Context` class are listed below:
Method | What it provides
:------|:----------------
@@ -607,9 +607,9 @@ In this case, there are two input topics, `input-topic-1` and `input-topic-2`, e
When using Pulsar Functions for Python, you essentially have three SerDe options:
-1. You can use the [`IdentitySerde`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L70), which leaves the data unchanged. The `IdentitySerDe` is the **default**. Creating or running a function without explicitly specifying SerDe will mean that this option is used.
-2. You can use the [`PickeSerDe`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L62), which uses Python's [`pickle`](https://docs.python.org/3/library/pickle.html) for SerDe.
-3. You can create a custom SerDe class by implementing the baseline [`SerDe`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L50) class, which has just two methods: [`serialize`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L53) for converting the object into bytes, and [`deserialize`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L58) for converting bytes into an object of the required application-specific type.
+1. You can use the [`IdentitySerde`](https://github.com/apache/pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L70), which leaves the data unchanged. The `IdentitySerDe` is the **default**. Creating or running a function without explicitly specifying SerDe will mean that this option is used.
+2. You can use the [`PickeSerDe`](https://github.com/apache/pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L62), which uses Python's [`pickle`](https://docs.python.org/3/library/pickle.html) for SerDe.
+3. You can create a custom SerDe class by implementing the baseline [`SerDe`](https://github.com/apache/pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L50) class, which has just two methods: [`serialize`](https://github.com/apache/pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L53) for converting the object into bytes, and [`deserialize`](https://github.com/apache/pulsar/blob/master/pulsar-client-cpp/python/pulsar/functions/serde.py#L58) for converting bytes into an object of the required application-specific type.
The table below shows when you should use each SerDe:
diff --git a/site2/docs/functions-deploying.md b/site2/docs/functions-deploying.md
index 27f214c144a31..d6850dfadf4b7 100644
--- a/site2/docs/functions-deploying.md
+++ b/site2/docs/functions-deploying.md
@@ -12,7 +12,7 @@ Local run mode | The function runs in your local environment, for example on you
Cluster mode | The function runs *inside of* your Pulsar cluster, on the same machines as your Pulsar brokers
> #### Contributing new deployment modes
-> The Pulsar Functions feature was designed, however, with extensibility in mind. Other deployment options will be available in the future. If you'd like to add a new deployment option, we recommend getting in touch with the Pulsar developer community at [dev@pulsar.incubator.apache.org](mailto:dev@pulsar.incubator.apache.org).
+> The Pulsar Functions feature was designed, however, with extensibility in mind. Other deployment options will be available in the future. If you'd like to add a new deployment option, we recommend getting in touch with the Pulsar developer community at [dev@pulsar.apache.org](mailto:dev@pulsar.apache.org).
## Requirements
diff --git a/site2/docs/getting-started-clients.md b/site2/docs/getting-started-clients.md
index 85ef3dc4949aa..66fc11f8a374b 100644
--- a/site2/docs/getting-started-clients.md
+++ b/site2/docs/getting-started-clients.md
@@ -42,7 +42,7 @@ There are also [Doxygen](http://www.stack.nl/~dimitri/doxygen/)-generated API do
## Feature Matrix
-This matrix listing all the features among different languages in Pulsar master can be found [here](https://github.com/apache/incubator-pulsar/wiki/Client-Features-Matrix).
+This matrix listing all the features among different languages in Pulsar master can be found [here](https://github.com/apache/pulsar/wiki/Client-Features-Matrix).
## Thirdparty Clients
diff --git a/site2/docs/getting-started-standalone.md b/site2/docs/getting-started-standalone.md
index efafb22fcaf6a..601f33e37108d 100644
--- a/site2/docs/getting-started-standalone.md
+++ b/site2/docs/getting-started-standalone.md
@@ -25,7 +25,7 @@ To get started running Pulsar, download a binary tarball release in one of the f
* Pulsar {{pulsar:version}} binary release
* from the Pulsar [downloads page](pulsar:download_page_url)
-* from the Pulsar [releases page](https://github.com/apache/incubator-pulsar/releases/latest)
+* from the Pulsar [releases page](https://github.com/apache/pulsar/releases/latest)
* using [wget](https://www.gnu.org/software/wget):
```shell
@@ -70,7 +70,7 @@ If you would like to enable those `builtin` connectors, you can download the con
* Pulsar IO Connectors {{pulsar:version}} release
* from the Pulsar [downloads page](pulsar:download_page_url)
-* from the Pulsar [releases page](https://github.com/apache/incubator-pulsar/releases/latest)
+* from the Pulsar [releases page](https://github.com/apache/pulsar/releases/latest)
* using [wget](https://www.gnu.org/software/wget):
```shell
diff --git a/site2/docs/io-overview.md b/site2/docs/io-overview.md
index 0c5571628e5d2..2319dd7f8f4ed 100644
--- a/site2/docs/io-overview.md
+++ b/site2/docs/io-overview.md
@@ -30,10 +30,10 @@ The following connectors are currently available for Pulsar:
|Name|Java Class|Documentation|
|---|---|---|
-|[Aerospike sink](https://www.aerospike.com/)|[`org.apache.pulsar.io.aerospike.AerospikeSink`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-io/aerospike/src/main/java/org/apache/pulsar/io/aerospike/AerospikeStringSink.java)|[Documentation](io-aerospike.md)|
-|[Cassandra sink](https://cassandra.apache.org)|[`org.apache.pulsar.io.cassandra.CassandraSink`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-io/cassandra/src/main/java/org/apache/pulsar/io/cassandra/CassandraStringSink.java)|[Documentation](io-cassandra.md)|
-|[Kafka source](https://kafka.apache.org)|[`org.apache.pulsar.io.kafka.KafkaSource`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-io/kafka/src/main/java/org/apache/pulsar/io/kafka/KafkaStringSource.java)|[Documentation](io-kafka.md#source)|
-|[Kafka sink](https://kafka.apache.org)|[`org.apache.pulsar.io.kafka.KafkaSink`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-io/kafka/src/main/java/org/apache/pulsar/io/kafka/KafkaStringSink.java)|[Documentation](io-kafka.md#sink)|
-|[Kinesis sink](https://aws.amazon.com/kinesis/)|[`org.apache.pulsar.io.kinesis.KinesisSink`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-io/kinesis/src/main/java/org/apache/pulsar/io/kinesis/KinesisSink.java)|[Documentation](io-kinesis.md#sink)|
-|[RabbitMQ source](https://www.rabbitmq.com)|[`org.apache.pulsar.io.rabbitmq.RabbitMQSource`](https://github.com/apache/incubator-pulsar/blob/master/pulsar-io/rabbitmq/src/main/java/org/apache/pulsar/io/rabbitmq/RabbitMQSource.java)|[Documentation](io-rabbitmq.md#sink)|
-|[Twitter Firehose source](https://developer.twitter.com/en/docs)|[org.apache.pulsar.io.twitter.TwitterFireHose](https://github.com/apache/incubator-pulsar/blob/master/pulsar-io/twitter/src/main/java/org/apache/pulsar/io/twitter/TwitterFireHose.java)|[Documentation](io-twitter.md#source)|
+|[Aerospike sink](https://www.aerospike.com/)|[`org.apache.pulsar.io.aerospike.AerospikeSink`](https://github.com/apache/pulsar/blob/master/pulsar-io/aerospike/src/main/java/org/apache/pulsar/io/aerospike/AerospikeStringSink.java)|[Documentation](io-aerospike.md)|
+|[Cassandra sink](https://cassandra.apache.org)|[`org.apache.pulsar.io.cassandra.CassandraSink`](https://github.com/apache/pulsar/blob/master/pulsar-io/cassandra/src/main/java/org/apache/pulsar/io/cassandra/CassandraStringSink.java)|[Documentation](io-cassandra.md)|
+|[Kafka source](https://kafka.apache.org)|[`org.apache.pulsar.io.kafka.KafkaSource`](https://github.com/apache/pulsar/blob/master/pulsar-io/kafka/src/main/java/org/apache/pulsar/io/kafka/KafkaStringSource.java)|[Documentation](io-kafka.md#source)|
+|[Kafka sink](https://kafka.apache.org)|[`org.apache.pulsar.io.kafka.KafkaSink`](https://github.com/apache/pulsar/blob/master/pulsar-io/kafka/src/main/java/org/apache/pulsar/io/kafka/KafkaStringSink.java)|[Documentation](io-kafka.md#sink)|
+|[Kinesis sink](https://aws.amazon.com/kinesis/)|[`org.apache.pulsar.io.kinesis.KinesisSink`](https://github.com/apache/pulsar/blob/master/pulsar-io/kinesis/src/main/java/org/apache/pulsar/io/kinesis/KinesisSink.java)|[Documentation](io-kinesis.md#sink)|
+|[RabbitMQ source](https://www.rabbitmq.com)|[`org.apache.pulsar.io.rabbitmq.RabbitMQSource`](https://github.com/apache/pulsar/blob/master/pulsar-io/rabbitmq/src/main/java/org/apache/pulsar/io/rabbitmq/RabbitMQSource.java)|[Documentation](io-rabbitmq.md#sink)|
+|[Twitter Firehose source](https://developer.twitter.com/en/docs)|[org.apache.pulsar.io.twitter.TwitterFireHose](https://github.com/apache/pulsar/blob/master/pulsar-io/twitter/src/main/java/org/apache/pulsar/io/twitter/TwitterFireHose.java)|[Documentation](io-twitter.md#source)|
diff --git a/site2/docs/io-quickstart.md b/site2/docs/io-quickstart.md
index 4a48bc09ce968..58bbff240d47b 100644
--- a/site2/docs/io-quickstart.md
+++ b/site2/docs/io-quickstart.md
@@ -26,7 +26,7 @@ To get started running Pulsar, download a binary tarball release in one of the f
* Pulsar {{pulsar:version}} binary release
* from the Pulsar [downloads page](pulsar:download_page_url)
-* from the Pulsar [releases page](https://github.com/apache/incubator-pulsar/releases/latest)
+* from the Pulsar [releases page](https://github.com/apache/pulsar/releases/latest)
* using [wget](https://www.gnu.org/software/wget):
```shell
@@ -50,7 +50,7 @@ If you would like to enable those `builtin` connectors, you can download the con
* Pulsar IO Connectors {{pulsar:version}} release
* from the Pulsar [downloads page](pulsar:download_page_url)
-* from the Pulsar [releases page](https://github.com/apache/incubator-pulsar/releases/latest)
+* from the Pulsar [releases page](https://github.com/apache/pulsar/releases/latest)
* using [wget](https://www.gnu.org/software/wget):
```shell
diff --git a/site2/docs/reference-configuration.md b/site2/docs/reference-configuration.md
index b74a928bcac1b..08df5d1e4cb92 100644
--- a/site2/docs/reference-configuration.md
+++ b/site2/docs/reference-configuration.md
@@ -11,7 +11,7 @@ sidebar_label: Pulsar configuration
-Pulsar configuration can be managed either via a series of configuration files contained in the [`conf`](https://github.com/apache/incubator-pulsar/tree/master/conf) directory of a Pulsar [installation](getting-started-standalone.md)
+Pulsar configuration can be managed either via a series of configuration files contained in the [`conf`](https://github.com/apache/pulsar/tree/master/conf) directory of a Pulsar [installation](getting-started-standalone.md)
* [BookKeeper](#bookkeeper)
* [Broker](#broker)
diff --git a/site2/docs/security-extending.md b/site2/docs/security-extending.md
index 436f240722751..d61582d087847 100644
--- a/site2/docs/security-extending.md
+++ b/site2/docs/security-extending.md
@@ -39,8 +39,8 @@ type of connection or by passing a certificate chain to use for TLS.
Examples for client authentication providers can be found at:
- * Mutual TLS Auth -- https://github.com/apache/incubator-pulsar/tree/master/pulsar-client/src/main/java/org/apache/pulsar/client/impl/auth
- * Athenz -- https://github.com/apache/incubator-pulsar/tree/master/pulsar-client-auth-athenz/src/main/java/org/apache/pulsar/client/impl/auth
+ * Mutual TLS Auth -- https://github.com/apache/pulsar/tree/master/pulsar-client/src/main/java/org/apache/pulsar/client/impl/auth
+ * Athenz -- https://github.com/apache/pulsar/tree/master/pulsar-client-auth-athenz/src/main/java/org/apache/pulsar/client/impl/auth
### Broker authentication plugin
@@ -94,8 +94,8 @@ public interface AuthenticationProvider extends Closeable {
Example for Broker authentication plugins:
- * Mutual TLS -- https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker-common/src/main/java/org/apache/pulsar/broker/authentication/AuthenticationProviderTls.java
- * Athenz -- https://github.com/apache/incubator-pulsar/blob/master/pulsar-broker-auth-athenz/src/main/java/org/apache/pulsar/broker/authentication/AuthenticationProviderAthenz.java
+ * Mutual TLS -- https://github.com/apache/pulsar/blob/master/pulsar-broker-common/src/main/java/org/apache/pulsar/broker/authentication/AuthenticationProviderTls.java
+ * Athenz -- https://github.com/apache/pulsar/blob/master/pulsar-broker-auth-athenz/src/main/java/org/apache/pulsar/broker/authentication/AuthenticationProviderAthenz.java
## Authorization
diff --git a/site2/docs/security-tls-transport.md b/site2/docs/security-tls-transport.md
index 460d2d0a6bcd9..9b29e76cd3e78 100644
--- a/site2/docs/security-tls-transport.md
+++ b/site2/docs/security-tls-transport.md
@@ -38,12 +38,12 @@ The following guide is an abridged guide to setting up a certificate authority.
The first step is to create the certificate for the CA. The CA will be used to sign both the broker and client certificates, in order to ensure that each party will trust the others. The CA should be stored in a very secure location (ideally completely disconnected from networks, air gapped, and fully encrypted).
-Create a directory for your CA, and place [this openssl configuration file](https://github.com/apache/incubator-pulsar/tree/master/site2/website/static/examples/openssl.cnf) in the directory. You may want to modify the default answers for company name and department in the configuration file. Export the location of the CA directory to the environment variable, CA_HOME. The configuration file uses this environment variable to find the rest of the files and directories needed for the CA.
+Create a directory for your CA, and place [this openssl configuration file](https://github.com/apache/pulsar/tree/master/site2/website/static/examples/openssl.cnf) in the directory. You may want to modify the default answers for company name and department in the configuration file. Export the location of the CA directory to the environment variable, CA_HOME. The configuration file uses this environment variable to find the rest of the files and directories needed for the CA.
```bash
$ mkdir my-ca
$ cd my-ca
-$ wget https://github.com/apache/incubator-pulsar/tree/master/site2/website/static/examples/openssl.cnf
+$ wget https://github.com/apache/pulsar/tree/master/site2/website/static/examples/openssl.cnf
$ export CA_HOME=$(pwd)
```
diff --git a/site2/website/contributing.md b/site2/website/contributing.md
index 310045a08ca3e..24f8e84711368 100644
--- a/site2/website/contributing.md
+++ b/site2/website/contributing.md
@@ -7,7 +7,7 @@ We use a review-then-commit workflow in Pulsar for all contributions.
**For larger contributions or those that affect multiple components:**
1. **Engage**: We encourage you to work with the Pulsar community on the
- [Github Issues](https://github.com/apache/incubator-pulsar/issues) and
+ [Github Issues](https://github.com/apache/pulsar/issues) and
[developer’s mailing list](/contact) to identify
good areas for contribution.
1. **Design:** More complicated contributions will likely benefit from some early discussion in
@@ -17,7 +17,7 @@ We use a review-then-commit workflow in Pulsar for all contributions.
1. **Code:** The best part ;-)
1. **Review:** Submit a pull request with your contribution to our
- [GitHub Repo](https://github.com/apache/incubator-pulsar). Work with a committer to review and
+ [GitHub Repo](https://github.com/apache/pulsar). Work with a committer to review and
iterate on the code, if needed.
1. **Commit:** Once at least 2 Pulsar committers have approved the pull request, a Pulsar committer
will merge it into the master branch (and potentially backport to stable branches in case of
@@ -29,22 +29,22 @@ We look forward to working with you!
### Mailing list(s)
-We discuss design and implementation issues on the [dev@pulsar.incubator.apache.org](mailto:dev@pulsar.incubator.apache.org)
+We discuss design and implementation issues on the [dev@pulsar.apache.org](mailto:dev@pulsar.apache.org)
mailing list, which is archived [here](https://lists.apache.org/list.html?dev@pulsar.apache.org).
-Join by emailing [`dev-subscribe@pulsar.incubator.apache.org`](mailto:dev-subscribe@pulsar.incubator.apache.org).
+Join by emailing [`dev-subscribe@pulsar.apache.org`](mailto:dev-subscribe@pulsar.apache.org).
If interested, you can also join the other [mailing lists](/contact).
### Github Issues
-We are using [Github Issues](https://github.com/apache/incubator-pulsar/issues) as the issue tracking
+We are using [Github Issues](https://github.com/apache/pulsar/issues) as the issue tracking
and project management tool, as well as a way to communicate among a very diverse and distributed set
of contributors. To be able to gather feedback, avoid frustration, and avoid duplicated efforts all
Pulsar related work are being tracked there.
If you do not already have an Github account, sign up [here](https://github.com/join).
-If a quick [search](https://github.com/apache/incubator-pulsar/issues) doesn’t turn up an existing
+If a quick [search](https://github.com/apache/pulsar/issues) doesn’t turn up an existing
Github issue for the work you want to contribute, create it. Please discuss your idea with a
committer in Github or, alternatively, on the developer mailing list.
@@ -72,7 +72,7 @@ To avoid potential frustration during the code review cycle, we encourage you to
design non-trivial contributions with the Pulsar community before you start coding.
We are using "Pulsar Improvement Proposals" (or "PIP") for managing major changes to Pulsar. The
-list of all PIPs is maintained in the Pulsar wiki at https://github.com/apache/incubator-pulsar/wiki.
+list of all PIPs is maintained in the Pulsar wiki at https://github.com/apache/pulsar/wiki.
## Code
@@ -95,7 +95,7 @@ If you do not already have a personal GitHub account, sign up [here](https://git
#### Fork the repository on GitHub
-Go to the [Pulsar GitHub Repo](https://github.com/apache/incubator-pulsar/) and fork the repository
+Go to the [Pulsar GitHub Repo](https://github.com/apache/pulsar/) and fork the repository
to your own private account. This will be your private workspace for staging changes.
#### Clone the repository locally
@@ -108,13 +108,13 @@ GitHub by following [their instructions](https://help.github.com/articles/genera
Clone your personal Pulsar’s GitHub fork.
- $ git clone https://github.com//incubator-pulsar.git
- $ cd incubator-pulsar
+ $ git clone https://github.com//pulsar.git
+ $ cd pulsar
Add Apache Repo as additional Git remotes, where you can sync the changes (for committers, you need
these two remotes for pushing changes).
- $ git remote add apache https://github.com/apache/incubator-pulsar
+ $ git remote add apache https://github.com/apache/pulsar
You are now ready to start developing!
@@ -226,7 +226,7 @@ Organize your commits to make a committer’s job easier when reviewing. Committ
You'll then push to your branch on GitHub. Note: when updating your commit after pull request feedback and use squash to get back to one commit, you will need to do a force submit to the branch on your repo.
-Navigate to the [Pulsar GitHub Repo](https://github.com/apache/incubator-pulsar) to create a pull request.
+Navigate to the [Pulsar GitHub Repo](https://github.com/apache/pulsar) to create a pull request.
In the pull request description, please include:
@@ -290,10 +290,10 @@ For smaller contributions, however, this is not required. In this case, we rely
### Website
-The Pulsar website is in the same [Pulsar Github Repo](https://github.com/apache/incubator-pulsar). The source files are hosted under `site2` directory in `master` branch,
+The Pulsar website is in the same [Pulsar Github Repo](https://github.com/apache/pulsar). The source files are hosted under `site2` directory in `master` branch,
the static content is generated by CI job and merged into the `asf-site` branch.
-Follow the [README](https://github.com/apache/incubator-pulsar/tree/master/site2) for making contributions to the website.
+Follow the [README](https://github.com/apache/pulsar/tree/master/site2) for making contributions to the website.
## Becoming a committer
diff --git a/site2/website/core/Footer.js b/site2/website/core/Footer.js
index 7d3cb45348b2e..8064dc8e4cd1a 100644
--- a/site2/website/core/Footer.js
+++ b/site2/website/core/Footer.js
@@ -118,8 +118,8 @@ class Footer extends React.Component {
const contactUrl = this.pageUrl('contact', this.props.language)
const eventsUrl = this.pageUrl('events', this.props.language)
const twitterUrl = 'https://twitter.com/Apache_Pulsar'
- const wikiUrl = 'https://github.com/apache/incubator-pulsar/wiki'
- const issuesUrl = 'https://github.com/apache/incubator-pulsar/issues'
+ const wikiUrl = 'https://github.com/apache/pulsar/wiki'
+ const issuesUrl = 'https://github.com/apache/pulsar/issues'
const resourcesUrl = this.pageUrl('resources', this.props.language)
const teamUrl = this.pageUrl('team', this.props.language)
const contributingUrl = this.pageUrl('contributing', this.props.language)
diff --git a/site2/website/pages/en/contact.js b/site2/website/pages/en/contact.js
index 2a662ac5e766f..f1a059728f643 100644
--- a/site2/website/pages/en/contact.js
+++ b/site2/website/pages/en/contact.js
@@ -16,25 +16,25 @@ class Contact extends React.Component {
let language = this.props.language || '';
const mailingLists = [
{
- email: 'users@pulsar.incubator.apache.org',
+ email: 'users@pulsar.apache.org',
desc: 'User-related discussions',
- subscribe: 'mailto:users@pulsar.incubator.apache.org',
- unsubscribe: 'mailto:users-unsubscribe@pulsar.incubator.apache.org',
- archives: 'http://mail-archives.apache.org/mod_mbox/incubator-pulsar-users/'
+ subscribe: 'mailto:users@pulsar.apache.org',
+ unsubscribe: 'mailto:users-unsubscribe@pulsar.apache.org',
+ archives: 'http://mail-archives.apache.org/mod_mbox/pulsar-users/'
},
{
- email: 'dev@pulsar.incubator.apache.org',
+ email: 'dev@pulsar.apache.org',
desc: 'Development-related discussions',
- subscribe: 'mailto:dev@pulsar.incubator.apache.org',
- unsubscribe: 'mailto:dev-unsubscribe@pulsar.incubator.apache.org',
- archives: 'http://mail-archives.apache.org/mod_mbox/incubator-pulsar-dev/'
+ subscribe: 'mailto:dev@pulsar.apache.org',
+ unsubscribe: 'mailto:dev-unsubscribe@pulsar.apache.org',
+ archives: 'http://mail-archives.apache.org/mod_mbox/pulsar-dev/'
},
{
- email: 'dev@pulsar.incubator.apache.org',
+ email: 'dev@pulsar.apache.org',
desc: 'All commits to the Pulsar repository',
- subscribe: 'mailto:commits-subscribe@pulsar.incubator.apache.org',
- unsubscribe: 'mailto:commits-unsubscribe@pulsar.incubator.apache.org',
- archives: 'http://mail-archives.apache.org/mod_mbox/incubator-pulsar-commits/'
+ subscribe: 'mailto:commits-subscribe@pulsar.apache.org',
+ unsubscribe: 'mailto:commits-unsubscribe@pulsar.apache.org',
+ archives: 'http://mail-archives.apache.org/mod_mbox/pulsar-commits/'
}
]
@@ -51,7 +51,7 @@ class Contact extends React.Component {
The mailing lists are the primary place where all Pulsar committers are present.
Bugs and feature requests can either be discussed on the dev mailing list or
by opening an issue on
- GitHub.
+ GitHub.
Mailing Lists
diff --git a/site2/website/pages/en/download.js b/site2/website/pages/en/download.js
index cea6f26e00d0b..55ad70e68a8e3 100644
--- a/site2/website/pages/en/download.js
+++ b/site2/website/pages/en/download.js
@@ -12,18 +12,28 @@ const translate = require('../../server/translate.js').translate;
const siteConfig = require(`${CWD}/siteConfig.js`);
const releases = require(`${CWD}/releases.json`);
-const archiveRootUrl = siteConfig.archiveRootUrl;
-
function getLatestArchiveMirrorUrl(version, type) {
- return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=incubator/pulsar/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ if (version.includes('incubating')) {
+ return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=incubator/pulsar/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ } else {
+ return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=pulsar/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ }
}
function distUrl(version, type) {
- return `https://www.apache.org/dist/incubator/pulsar/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ if (version.includes('incubating')) {
+ return `https://www.apache.org/dist/incubator/pulsar/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ } else {
+ return `https://www.apache.org/dist/pulsar/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ }
}
function archiveUrl(version, type) {
- return `${archiveRootUrl}/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ if (version.includes('incubating')) {
+ return `https://archive.apache.org/dist/incubator/pulsar/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ } else {
+ return `https://archive.apache.org/dist/pulsar/pulsar-${version}/apache-pulsar-${version}-${type}.tar.gz`
+ }
}
class Download extends React.Component {
@@ -63,7 +73,7 @@ class Download extends React.Component {
Binary |
- pulsar-{latestVersion}-bin.tar.gz
+ apache-pulsar-{latestVersion}-bin.tar.gz
|
asc,
@@ -73,7 +83,7 @@ class Download extends React.Component {
|
Source |
- pulsar-{latestVersion}-src.tar.gz
+ apache-pulsar-{latestVersion}-src.tar.gz
|
asc,
@@ -161,13 +171,13 @@ class Download extends React.Component {
|
{info.version} |
- pulsar-{info.version}-bin-tar.gz
+ apache-pulsar-{info.version}-bin-tar.gz
(asc,
sha512)
|
- pulsar-{info.version}-bin-tar.gz
+ apache-pulsar-{info.version}-bin-tar.gz
(asc
sha512)
diff --git a/site2/website/pages/en/index.js b/site2/website/pages/en/index.js
index b802b893b8e95..29165a14ac94d 100755
--- a/site2/website/pages/en/index.js
+++ b/site2/website/pages/en/index.js
@@ -164,17 +164,8 @@ const KeyFeautresGrid = props => (
const ApacheBlock = prop => (
-
- data:image/s3,"s3://crabby-images/b6a6c/b6a6c033b7c97f87caa6796e3ecec94938a6f471" alt=""})
-
- Apache Pulsar is an effort undergoing incubation at The Apache Software Foundation (ASF)
- sponsored by the Apache Incubator PMC. Incubation is required of all newly accepted projects
- until a further review indicates that the infrastructure, communications, and decision making
- process have stabilized in a manner consistent with other successful ASF projects.
- While incubation status is not necessarily a reflection of the completeness or stability of the code,
- it does indicate that the project has yet to be fully endorsed by the ASF.
- Apache Pulsar (incubating) is available under the Apache License, version 2.0.
+ Apache Pulsar is available under the Apache License, version 2.0.
diff --git a/site2/website/scripts/replace.js b/site2/website/scripts/replace.js
index 2970688dce92e..228b29e30aec6 100644
--- a/site2/website/scripts/replace.js
+++ b/site2/website/scripts/replace.js
@@ -22,24 +22,44 @@ function downloadPageUrl() {
}
function binaryReleaseUrl(version) {
- return `https://archive.apache.org/dist/incubator/pulsar/pulsar-${version}/apache-pulsar-${version}-bin.tar.gz`
+ if (version.includes('incubating')) {
+ return `https://archive.apache.org/dist/incubator/pulsar/pulsar-${version}/apache-pulsar-${version}-bin.tar.gz`
+ } else {
+ return `https://archive.apache.org/dist/pulsar/pulsar-${version}/apache-pulsar-${version}-bin.tar.gz`
+ }
}
function connectorReleaseUrl(version) {
- return `https://archive.apache.org/dist/incubator/pulsar/pulsar-${version}/apache-pulsar-io-connectors-${version}-bin.tar.gz`
+ if (version.includes('incubating')) {
+ return `https://archive.apache.org/dist/incubator/pulsar/pulsar-${version}/apache-pulsar-io-connectors-${version}-bin.tar.gz`
+ } else {
+ return `https://archive.apache.org/dist/pulsar/pulsar-${version}/apache-pulsar-io-connectors-${version}-bin.tar.gz`
+ }
}
function prestoPulsarReleaseUrl(version) {
- return `https://archive.apache.org/dist/incubator/pulsar/pulsar-${version}/pulsar-presto-connector-${version}.tar.gz`
+ if (version.includes('incubating')) {
+ return `https://archive.apache.org/dist/incubator/pulsar/pulsar-${version}/pulsar-presto-connector-${version}.tar.gz`
+ } else {
+ return `https://archive.apache.org/dist/pulsar/pulsar-${version}/pulsar-presto-connector-${version}.tar.gz`
+ }
}
function rpmReleaseUrl(version, type) {
rpmVersion = version.replace('incubating', '1_incubating');
- return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=incubator/pulsar/pulsar-${version}/RPMS/apache-pulsar-client${type}-${rpmVersion}.x86_64.rpm`
+ if (version.includes('incubating')) {
+ return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=incubator/pulsar/pulsar-${version}/RPMS/apache-pulsar-client${type}-${rpmVersion}.x86_64.rpm`
+ } else {
+ return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=pulsar/pulsar-${version}/RPMS/apache-pulsar-client${type}-${rpmVersion}.x86_64.rpm`
+ }
}
function debReleaseUrl(version, type) {
- return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=incubator/pulsar/pulsar-${version}/DEB/apache-pulsar-client${type}.deb`
+ if (version.includes('incubating')) {
+ return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=incubator/pulsar/pulsar-${version}/DEB/apache-pulsar-client${type}.deb`
+ } else {
+ return `https://www.apache.org/dyn/mirrors/mirrors.cgi?action=download&filename=pulsar/pulsar-${version}/DEB/apache-pulsar-client${type}.deb`
+ }
}
function doReplace(options) {
@@ -63,7 +83,7 @@ const latestVersionWithoutIncubating = latestVersion.replace('-incubating', '');
const from = [
/{{pulsar:version_number}}/g,
- /{{pulsar:version}}/g,
+ /{{pulsar:version}}/g,
/pulsar:binary_release_url/g,
/pulsar:connector_release_url/g,
/pulsar:presto_pulsar_connector_release_url/g,
@@ -77,15 +97,15 @@ const from = [
const options = {
files: [
- `${docsDir}/*.html`,
+ `${docsDir}/*.html`,
`${docsDir}/**/*.html`
],
ignore: versions.map(v => `${docsDir}/${v}/**/*`), // TODO add next and assets
from: from,
to: [
- `${latestVersionWithoutIncubating}`,
- `${latestVersion}`,
- binaryReleaseUrl(`${latestVersion}`),
+ `${latestVersionWithoutIncubating}`,
+ `${latestVersion}`,
+ binaryReleaseUrl(`${latestVersion}`),
connectorReleaseUrl(`${latestVersion}`),
prestoPulsarReleaseUrl(`${latestVersion}`),
downloadPageUrl(),
@@ -109,13 +129,13 @@ for (v of versions) {
const vWithoutIncubating = v.replace('-incubating', '');
const opts = {
files: [
- `${docsDir}/${v}/*.html`,
+ `${docsDir}/${v}/*.html`,
`${docsDir}/${v}/**/*.html`
],
from: from,
to: [
- `${vWithoutIncubating}`,
- `${v}`,
+ `${vWithoutIncubating}`,
+ `${v}`,
binaryReleaseUrl(`${v}`),
connectorReleaseUrl(`${v}`),
prestoPulsarReleaseUrl(`${latestVersion}`),
diff --git a/site2/website/siteConfig.js b/site2/website/siteConfig.js
index 6a3196cca5ad2..6cbf22f2226b5 100644
--- a/site2/website/siteConfig.js
+++ b/site2/website/siteConfig.js
@@ -166,7 +166,6 @@ const siteConfig = {
},
githubUrl: githubUrl,
- archiveRootUrl: 'https://archive.apache.org/dist/incubator/pulsar',
projectDescription: `
Apache Pulsar is an open-source distributed pub-sub messaging system originally
|