You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@inlong.apache.org by go...@apache.org on 2023/01/30 04:57:06 UTC

[inlong] branch master updated: [INLONG-7280][Manager] rename checkXXX to expectXXX in Preconditions (#7282)

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

gosonzhang pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/inlong.git


The following commit(s) were added to refs/heads/master by this push:
     new df90ad4ef [INLONG-7280][Manager] rename checkXXX to expectXXX in Preconditions (#7282)
df90ad4ef is described below

commit df90ad4ef621d1f2056b1eb308989daf541ab822
Author: Goson Zhang <46...@qq.com>
AuthorDate: Mon Jan 30 12:57:00 2023 +0800

    [INLONG-7280][Manager] rename checkXXX to expectXXX in Preconditions (#7282)
---
 .../manager/client/api/InlongGroupContext.java     |  2 +-
 .../manager/client/api/impl/DataNodeImpl.java      | 25 +++---
 .../manager/client/api/impl/HeartbeatImpl.java     | 51 +++++++-----
 .../manager/client/api/impl/InlongClientImpl.java  | 44 +++++------
 .../manager/client/api/impl/InlongConsumeImpl.java | 14 ++--
 .../manager/client/api/impl/InlongGroupImpl.java   | 18 ++---
 .../manager/client/api/impl/InlongStreamImpl.java  | 18 ++---
 .../inlong/manager/client/api/impl/NoAuthImpl.java |  8 +-
 .../manager/client/api/impl/StreamSourceImpl.java  |  4 +-
 .../inlong/manager/client/api/impl/UserImpl.java   | 16 ++--
 .../manager/client/api/impl/WorkflowImpl.java      | 18 ++---
 .../client/api/inner/InnerGroupContext.java        |  6 +-
 .../client/api/inner/client/DataNodeClient.java    | 30 ++++----
 .../client/api/inner/client/HeartbeatClient.java   | 38 ++++-----
 .../api/inner/client/InlongClusterClient.java      | 28 +++----
 .../api/inner/client/InlongConsumeClient.java      | 14 ++--
 .../client/api/inner/client/InlongGroupClient.java |  4 +-
 .../api/inner/client/InlongStreamClient.java       | 24 +++---
 .../client/api/inner/client/NoAuthClient.java      |  8 +-
 .../client/api/inner/client/StreamSinkClient.java  |  2 +-
 .../api/inner/client/StreamSourceClient.java       |  8 +-
 .../api/inner/client/StreamTransformClient.java    |  6 +-
 .../client/api/inner/client/UserClient.java        | 16 ++--
 .../api/inner/client/WorkflowApproverClient.java   | 16 ++--
 .../client/api/inner/client/WorkflowClient.java    | 18 ++---
 .../api/inner/client/WorkflowEventClient.java      | 18 ++---
 .../api/transform/MultiDependencyTransform.java    |  6 +-
 .../api/transform/SingleDependencyTransform.java   |  6 +-
 .../manager/client/api/util/ClientUtils.java       |  8 +-
 .../client/api/util/InlongGroupTransfer.java       |  8 +-
 .../client/api/util/StreamTransformTransfer.java   |  4 +-
 .../manager/common/auth/DefaultAuthentication.java |  2 +-
 .../manager/common/auth/SecretAuthentication.java  |  2 +-
 .../manager/common/auth/TokenAuthentication.java   |  2 +-
 .../inlong/manager/common/enums/FieldType.java     |  2 +-
 .../inlong/manager/common/util/HttpUtils.java      |  2 +-
 .../manager/common/util/InlongCollectionUtils.java |  4 +-
 .../inlong/manager/common/util/Preconditions.java  | 90 +++++++++++-----------
 .../manager/pojo/sink/hudi/HudiPartition.java      |  2 +-
 .../pojo/sink/iceberg/IcebergPartition.java        |  2 +-
 .../manager/pojo/sort/util/FieldRelationUtils.java |  6 +-
 .../pojo/sort/util/FilterFunctionUtils.java        |  2 +-
 .../manager/pojo/sort/util/StreamParseUtils.java   |  2 +-
 .../inlong/manager/pojo/stream/StreamNode.java     |  4 +-
 .../manager/pojo/stream/StreamNodeRelation.java    |  4 +-
 .../inlong/manager/pojo/stream/StreamPipeline.java |  2 +-
 .../form/process/ApplyConsumeProcessForm.java      |  2 +-
 .../form/process/ApplyGroupProcessForm.java        |  2 +-
 .../form/process/GroupResourceProcessForm.java     |  2 +-
 .../workflow/form/task/ConsumeApproveForm.java     |  2 +-
 .../workflow/form/task/InlongGroupApproveForm.java |  2 +-
 .../service/cluster/InlongClusterServiceImpl.java  | 68 ++++++++--------
 .../service/cluster/KafkaClusterOperator.java      |  2 +-
 .../service/cluster/TubeClusterOperator.java       |  2 +-
 .../service/consume/ConsumeKafkaOperator.java      |  6 +-
 .../service/consume/ConsumePulsarOperator.java     | 12 +--
 .../service/consume/ConsumeTubeMQOperator.java     |  6 +-
 .../service/consume/InlongConsumeServiceImpl.java  | 22 +++---
 .../service/core/impl/AgentServiceImpl.java        |  8 +-
 .../service/core/impl/AuditServiceImpl.java        |  2 +-
 .../manager/service/core/impl/SortServiceImpl.java |  2 +-
 .../core/impl/WorkflowApproverServiceImpl.java     | 20 ++---
 .../manager/service/group/GroupCheckService.java   |  2 +-
 .../service/group/InlongGroupProcessService.java   |  2 +-
 .../service/group/InlongGroupServiceImpl.java      | 18 ++---
 .../service/heartbeat/HeartbeatManager.java        |  6 +-
 .../service/heartbeat/HeartbeatServiceImpl.java    | 38 ++++-----
 .../apply/ApproveConsumeProcessListener.java       |  8 +-
 .../manager/service/node/DataNodeServiceImpl.java  |  4 +-
 .../node/ck/ClickHouseDataNodeOperator.java        |  2 +-
 .../node/es/ElasticsearchDataNodeOperator.java     |  2 +-
 .../service/node/hive/HiveDataNodeOperator.java    |  2 +-
 .../node/iceberg/IcebergDataNodeOperator.java      |  2 +-
 .../service/node/mysql/MySQLDataNodeOperator.java  |  2 +-
 .../node/starrocks/StarRocksDataNodeOperator.java  |  2 +-
 .../manager/service/plugin/PluginClassLoader.java  |  6 +-
 .../queue/kafka/KafkaResourceOperators.java        | 12 +--
 .../resource/queue/pulsar/PulsarOperator.java      | 10 +--
 .../queue/pulsar/PulsarResourceOperator.java       | 16 ++--
 .../service/resource/queue/pulsar/PulsarUtils.java |  2 +-
 .../queue/tubemq/TubeMQResourceOperator.java       |  4 +-
 .../sink/ck/ClickHouseResourceOperator.java        |  2 +-
 .../resource/sink/hive/HiveResourceOperator.java   |  2 +-
 .../resource/sink/hudi/HudiResourceOperator.java   |  2 +-
 .../sink/iceberg/IcebergResourceOperator.java      |  2 +-
 .../resource/sink/kafka/KafkaResourceOperator.java |  4 +-
 .../resource/sink/mysql/MySQLResourceOperator.java |  2 +-
 .../sink/starrocks/StarRocksResourceOperator.java  |  2 +-
 .../service/sink/StreamSinkServiceImpl.java        | 46 +++++------
 .../service/source/StreamSourceServiceImpl.java    | 36 ++++-----
 .../service/stream/InlongStreamProcessService.java | 14 ++--
 .../service/stream/InlongStreamServiceImpl.java    | 40 +++++-----
 .../transform/StreamTransformServiceImpl.java      | 22 +++---
 .../manager/service/user/UserServiceImpl.java      | 38 ++++-----
 .../service/workflow/WorkflowServiceImpl.java      |  6 +-
 .../auth/openapi/OpenAPIAuthenticatingRealm.java   |  4 +-
 .../manager/web/auth/web/AuthenticationFilter.java |  4 +-
 .../manager/web/auth/web/WebAuthorizingRealm.java  |  4 +-
 .../controller/openapi/OpenDataNodeController.java | 20 ++---
 .../openapi/OpenInLongClusterController.java       | 70 ++++++++---------
 .../openapi/OpenInLongGroupController.java         | 24 +++---
 .../openapi/OpenInLongStreamController.java        | 27 +++----
 .../openapi/OpenStreamSinkController.java          | 20 ++---
 .../openapi/OpenStreamSourceController.java        | 20 ++---
 .../openapi/OpenStreamTransformController.java     | 16 ++--
 .../core/impl/EventListenerServiceImpl.java        |  2 +-
 .../impl/MemoryProcessDefinitionRepository.java    |  2 +-
 .../core/impl/ProcessDefinitionServiceImpl.java    |  2 +-
 .../workflow/core/impl/ProcessServiceImpl.java     | 16 ++--
 .../core/impl/WorkflowContextBuilderImpl.java      |  4 +-
 .../manager/workflow/definition/Element.java       |  4 +-
 .../workflow/definition/NextableElement.java       |  6 +-
 .../manager/workflow/definition/ServiceTask.java   |  2 +-
 .../manager/workflow/definition/UserTask.java      |  2 +-
 .../workflow/definition/WorkflowProcess.java       |  6 +-
 .../AbstractNextableElementProcessor.java          |  2 +-
 .../workflow/processor/ServiceTaskProcessor.java   |  4 +-
 .../workflow/processor/StartEventProcessor.java    |  6 +-
 .../workflow/processor/UserTaskProcessor.java      | 14 ++--
 .../manager/workflow/util/WorkflowUtils.java       | 10 +--
 120 files changed, 717 insertions(+), 706 deletions(-)

diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/InlongGroupContext.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/InlongGroupContext.java
index e151c59e6..2d0ae4e40 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/InlongGroupContext.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/InlongGroupContext.java
@@ -65,7 +65,7 @@ public class InlongGroupContext implements Serializable {
 
     public InlongGroupContext(InnerGroupContext groupContext) {
         InlongGroupInfo groupInfo = groupContext.getGroupInfo();
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
         this.groupId = groupInfo.getInlongGroupId();
         this.groupName = groupInfo.getName();
         this.groupInfo = groupInfo;
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/DataNodeImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/DataNodeImpl.java
index b1c6ec340..b9cf193c6 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/DataNodeImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/DataNodeImpl.java
@@ -22,6 +22,7 @@ import org.apache.inlong.manager.client.api.DataNode;
 import org.apache.inlong.manager.client.api.inner.client.ClientFactory;
 import org.apache.inlong.manager.client.api.inner.client.DataNodeClient;
 import org.apache.inlong.manager.client.api.util.ClientUtils;
+import org.apache.inlong.manager.common.enums.ErrorCodeEnum;
 import org.apache.inlong.manager.common.util.Preconditions;
 import org.apache.inlong.manager.pojo.common.PageResult;
 import org.apache.inlong.manager.pojo.node.DataNodeInfo;
@@ -38,36 +39,40 @@ public class DataNodeImpl implements DataNode {
 
     @Override
     public Integer save(DataNodeRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
-        Preconditions.checkNotEmpty(request.getName(), "data node name cannot be empty");
-        Preconditions.checkNotEmpty(request.getType(), "data node type cannot be empty");
+        Preconditions.expectNotNull(request, "request cannot be null");
+        Preconditions.expectNotBlank(request.getName(), ErrorCodeEnum.INVALID_PARAMETER,
+                "data node name cannot be blank");
+        Preconditions.expectNotBlank(request.getType(), ErrorCodeEnum.INVALID_PARAMETER,
+                "data node type cannot be blank");
         return dataNodeClient.save(request);
     }
 
     @Override
     public DataNodeInfo get(Integer id) {
-        Preconditions.checkNotNull(id, "data node id cannot be null");
+        Preconditions.expectNotNull(id, "data node id cannot be null");
         return dataNodeClient.get(id);
     }
 
     @Override
     public PageResult<DataNodeInfo> list(DataNodeRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
+        Preconditions.expectNotNull(request, "request cannot be null");
         return dataNodeClient.list(request);
     }
 
     @Override
     public Boolean update(DataNodeRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
-        Preconditions.checkNotEmpty(request.getName(), "data node name cannot be empty");
-        Preconditions.checkNotEmpty(request.getType(), "data node type cannot be empty");
-        Preconditions.checkNotNull(request.getId(), "data node id cannot be null");
+        Preconditions.expectNotNull(request, "request cannot be null");
+        Preconditions.expectNotBlank(request.getName(), ErrorCodeEnum.INVALID_PARAMETER,
+                "data node name cannot be empty");
+        Preconditions.expectNotBlank(request.getType(), ErrorCodeEnum.INVALID_PARAMETER,
+                "data node type cannot be empty");
+        Preconditions.expectNotNull(request.getId(), "data node id cannot be null");
         return dataNodeClient.update(request);
     }
 
     @Override
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "data node id cannot be null");
+        Preconditions.expectNotNull(id, "data node id cannot be null");
         return dataNodeClient.delete(id);
     }
 }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/HeartbeatImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/HeartbeatImpl.java
index 9d2f7079c..1a29e4523 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/HeartbeatImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/HeartbeatImpl.java
@@ -45,55 +45,68 @@ public class HeartbeatImpl implements Heartbeat {
 
     @Override
     public ComponentHeartbeatResponse getComponentHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotBlank(request.getComponent(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat component cannot be blank");
+        Preconditions.expectNotBlank(request.getInstance(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat instance cannot be blank");
 
         return heartbeatClient.getComponentHeartbeat(request);
     }
 
     @Override
     public GroupHeartbeatResponse getGroupHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotBlank(request.getComponent(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat component cannot be blank");
+        Preconditions.expectNotBlank(request.getInstance(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat instance cannot be blank");
+        Preconditions.expectNotBlank(request.getInlongGroupId(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat groupId cannot be blank");
 
         return heartbeatClient.getGroupHeartbeat(request);
     }
 
     @Override
     public StreamHeartbeatResponse getStreamHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongStreamId(), ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotBlank(request.getComponent(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat component cannot be blank");
+        Preconditions.expectNotBlank(request.getInstance(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat instance cannot be blank");
+        Preconditions.expectNotBlank(request.getInlongGroupId(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat groupId cannot be blank");
+        Preconditions.expectNotBlank(request.getInlongStreamId(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat streamId cannot be blank");
 
         return heartbeatClient.getStreamHeartbeat(request);
     }
 
     @Override
     public PageResult<ComponentHeartbeatResponse> listComponentHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotBlank(request.getComponent(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat component cannot be blank");
 
         return heartbeatClient.listComponentHeartbeat(request);
     }
 
     @Override
     public PageResult<GroupHeartbeatResponse> listGroupHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotBlank(request.getComponent(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat component cannot be blank");
 
         return heartbeatClient.listGroupHeartbeat(request);
     }
 
     @Override
     public PageResult<StreamHeartbeatResponse> listStreamHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotBlank(request.getComponent(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat component cannot be blank");
+        Preconditions.expectNotBlank(request.getInlongGroupId(), ErrorCodeEnum.INVALID_PARAMETER,
+                "heartbeat groupId cannot be blank");
 
         return heartbeatClient.listStreamHeartbeat(request);
     }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongClientImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongClientImpl.java
index c8f988e44..33c691163 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongClientImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongClientImpl.java
@@ -182,14 +182,14 @@ public class InlongClientImpl implements InlongClient {
 
     @Override
     public Integer saveTag(ClusterTagRequest request) {
-        Preconditions.checkNotNull(request, "inlong cluster request cannot be empty");
-        Preconditions.checkNotNull(request.getClusterTag(), "cluster tag cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster request cannot be empty");
+        Preconditions.expectNotNull(request.getClusterTag(), "cluster tag cannot be empty");
         return clusterClient.saveTag(request);
     }
 
     @Override
     public ClusterTagResponse getTag(Integer id) {
-        Preconditions.checkNotNull(id, "inlong cluster tag id cannot be empty");
+        Preconditions.expectNotNull(id, "inlong cluster tag id cannot be empty");
         return clusterClient.getTag(id);
     }
 
@@ -200,27 +200,27 @@ public class InlongClientImpl implements InlongClient {
 
     @Override
     public Boolean updateTag(ClusterTagRequest request) {
-        Preconditions.checkNotNull(request, "inlong cluster request cannot be empty");
-        Preconditions.checkNotNull(request.getClusterTag(), "inlong cluster tag cannot be empty");
-        Preconditions.checkNotNull(request.getId(), "cluster tag id cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster request cannot be empty");
+        Preconditions.expectNotNull(request.getClusterTag(), "inlong cluster tag cannot be empty");
+        Preconditions.expectNotNull(request.getId(), "cluster tag id cannot be empty");
         return clusterClient.updateTag(request);
     }
 
     @Override
     public Boolean deleteTag(Integer id) {
-        Preconditions.checkNotNull(id, "cluster tag id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster tag id cannot be empty");
         return clusterClient.deleteTag(id);
     }
 
     @Override
     public Integer saveCluster(ClusterRequest request) {
-        Preconditions.checkNotNull(request, "inlong cluster request cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster request cannot be empty");
         return clusterClient.saveCluster(request);
     }
 
     @Override
     public ClusterInfo get(Integer id) {
-        Preconditions.checkNotNull(id, "inlong cluster id cannot be empty");
+        Preconditions.expectNotNull(id, "inlong cluster id cannot be empty");
         return clusterClient.get(id);
     }
 
@@ -231,59 +231,59 @@ public class InlongClientImpl implements InlongClient {
 
     @Override
     public Boolean update(ClusterRequest request) {
-        Preconditions.checkNotNull(request, "inlong cluster info cannot be empty");
-        Preconditions.checkNotNull(request.getId(), "inlong cluster id cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster info cannot be empty");
+        Preconditions.expectNotNull(request.getId(), "inlong cluster id cannot be empty");
         return clusterClient.update(request);
     }
 
     @Override
     public Boolean bindTag(BindTagRequest request) {
-        Preconditions.checkNotNull(request, "inlong cluster info cannot be empty");
-        Preconditions.checkNotNull(request.getClusterTag(), "cluster tag cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster info cannot be empty");
+        Preconditions.expectNotNull(request.getClusterTag(), "cluster tag cannot be empty");
         return clusterClient.bindTag(request);
     }
 
     @Override
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "cluster id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster id cannot be empty");
         return clusterClient.delete(id);
     }
 
     @Override
     public Integer saveNode(ClusterNodeRequest request) {
-        Preconditions.checkNotNull(request, "cluster node info cannot be empty");
+        Preconditions.expectNotNull(request, "cluster node info cannot be empty");
         return clusterClient.saveNode(request);
     }
 
     @Override
     public ClusterNodeResponse getNode(Integer id) {
-        Preconditions.checkNotNull(id, "cluster node id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster node id cannot be empty");
         return clusterClient.getNode(id);
     }
 
     @Override
     public PageResult<ClusterNodeResponse> listNode(ClusterPageRequest request) {
-        Preconditions.checkNotNull(request.getParentId(), "parentId cannot be empty");
+        Preconditions.expectNotNull(request.getParentId(), "parentId cannot be empty");
         return clusterClient.listNode(request);
     }
 
     @Override
     public List<ClusterNodeResponse> listNode(String inlongGroupId, String clusterType, String protocolType) {
-        Preconditions.checkNotNull(inlongGroupId, "inlongGroupId cannot be empty");
-        Preconditions.checkNotNull(clusterType, "clusterType cannot be empty");
+        Preconditions.expectNotNull(inlongGroupId, "inlongGroupId cannot be empty");
+        Preconditions.expectNotNull(clusterType, "clusterType cannot be empty");
         return clusterClient.listNode(inlongGroupId, clusterType, protocolType);
     }
 
     @Override
     public Boolean updateNode(ClusterNodeRequest request) {
-        Preconditions.checkNotNull(request, "inlong cluster node cannot be empty");
-        Preconditions.checkNotNull(request.getId(), "cluster node id cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster node cannot be empty");
+        Preconditions.expectNotNull(request.getId(), "cluster node id cannot be empty");
         return clusterClient.updateNode(request);
     }
 
     @Override
     public Boolean deleteNode(Integer id) {
-        Preconditions.checkNotNull(id, "cluster node id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster node id cannot be empty");
         return clusterClient.deleteNode(id);
     }
 
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongConsumeImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongConsumeImpl.java
index cc0139d56..25c0dc08c 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongConsumeImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongConsumeImpl.java
@@ -42,16 +42,16 @@ public class InlongConsumeImpl implements InlongConsume {
 
     @Override
     public Integer save(InlongConsumeRequest request) {
-        Preconditions.checkNotNull(request, "inlong consume request cannot be null");
-        Preconditions.checkNotNull(request.getTopic(), "inlong consume topic cannot be null");
-        Preconditions.checkNotNull(request.getConsumerGroup(), "inlong consume topic cannot be null");
+        Preconditions.expectNotNull(request, "inlong consume request cannot be null");
+        Preconditions.expectNotNull(request.getTopic(), "inlong consume topic cannot be null");
+        Preconditions.expectNotNull(request.getConsumerGroup(), "inlong consume topic cannot be null");
 
         return consumeClient.save(request);
     }
 
     @Override
     public InlongConsumeInfo get(Integer id) {
-        Preconditions.checkNotNull(id, "inlong consume id cannot be null");
+        Preconditions.expectNotNull(id, "inlong consume id cannot be null");
 
         return consumeClient.get(id);
     }
@@ -68,21 +68,21 @@ public class InlongConsumeImpl implements InlongConsume {
 
     @Override
     public Integer update(InlongConsumeRequest request) {
-        Preconditions.checkNotNull(request, "inlong consume request cannot be null");
+        Preconditions.expectNotNull(request, "inlong consume request cannot be null");
 
         return consumeClient.update(request);
     }
 
     @Override
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "inlong consume id cannot be null");
+        Preconditions.expectNotNull(id, "inlong consume id cannot be null");
 
         return consumeClient.delete(id);
     }
 
     @Override
     public WorkflowResult startProcess(Integer id) {
-        Preconditions.checkNotNull(id, "inlong consume id cannot be null");
+        Preconditions.expectNotNull(id, "inlong consume id cannot be null");
 
         return consumeClient.startProcess(id);
     }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongGroupImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongGroupImpl.java
index 2f6538e22..1a571dd3b 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongGroupImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongGroupImpl.java
@@ -118,11 +118,11 @@ public class InlongGroupImpl implements InlongGroup {
         InlongGroupInfo groupInfo = this.groupContext.getGroupInfo();
         WorkflowResult initWorkflowResult = groupClient.initInlongGroup(groupInfo.genRequest());
         List<TaskResponse> taskViews = initWorkflowResult.getNewTasks();
-        Preconditions.checkNotEmpty(taskViews, "init inlong group info failed");
+        Preconditions.expectNotEmpty(taskViews, "init inlong group info failed");
         TaskResponse taskView = taskViews.get(0);
         final int taskId = taskView.getId();
         ProcessResponse processView = initWorkflowResult.getProcessInfo();
-        Preconditions.checkTrue(ProcessStatus.PROCESSING == processView.getStatus(),
+        Preconditions.expectTrue(ProcessStatus.PROCESSING == processView.getStatus(),
                 String.format("process status %s is not corrected, should be PROCESSING", processView.getStatus()));
 
         // init must be ApplyGroupProcessForm
@@ -140,12 +140,12 @@ public class InlongGroupImpl implements InlongGroup {
         String formDataNew = formDataJson.toString();
         ApplyGroupProcessForm groupProcessForm = JsonUtils.parseObject(
                 formDataNew, ApplyGroupProcessForm.class);
-        Preconditions.checkNotNull(groupProcessForm, "ApplyGroupProcessForm cannot be null");
+        Preconditions.expectNotNull(groupProcessForm, "ApplyGroupProcessForm cannot be null");
         groupContext.setInitMsg(groupProcessForm);
         assert groupProcessForm != null;
         WorkflowResult startWorkflowResult = workflowClient.startInlongGroup(taskId, groupProcessForm);
         processView = startWorkflowResult.getProcessInfo();
-        Preconditions.checkTrue(ProcessStatus.COMPLETED == processView.getStatus(),
+        Preconditions.expectTrue(ProcessStatus.COMPLETED == processView.getStatus(),
                 String.format("inlong group status %s is incorrect, should be COMPLETED", processView.getStatus()));
         return generateSnapshot();
     }
@@ -156,7 +156,7 @@ public class InlongGroupImpl implements InlongGroup {
             originGroupInfo = this.groupInfo;
         }
 
-        Preconditions.checkTrue(Objects.equal(originGroupInfo.getInlongGroupId(), this.groupInfo.getInlongGroupId()),
+        Preconditions.expectTrue(Objects.equal(originGroupInfo.getInlongGroupId(), this.groupInfo.getInlongGroupId()),
                 "groupId must be same");
 
         InlongGroupInfo groupInfo = InlongGroupTransfer.createGroupInfo(originGroupInfo, sortConf);
@@ -166,21 +166,21 @@ public class InlongGroupImpl implements InlongGroup {
 
     @Override
     public void update(BaseSortConf sortConf) throws Exception {
-        Preconditions.checkNotNull(sortConf, "sort conf cannot be null");
+        Preconditions.expectNotNull(sortConf, "sort conf cannot be null");
         this.updateOpt(InlongGroupTransfer.createGroupInfo(this.groupInfo, sortConf));
     }
 
     private void updateOpt(InlongGroupInfo groupInfo) {
         InlongGroupInfo existGroupInfo = groupClient.getGroupInfo(groupInfo.getInlongGroupId());
-        Preconditions.checkNotNull(existGroupInfo, "inlong group does not exist, cannot be updated");
+        Preconditions.expectNotNull(existGroupInfo, "inlong group does not exist, cannot be updated");
         SimpleGroupStatus status = SimpleGroupStatus.parseStatusByCode(existGroupInfo.getStatus());
-        Preconditions.checkTrue(status != SimpleGroupStatus.INITIALIZING,
+        Preconditions.expectTrue(status != SimpleGroupStatus.INITIALIZING,
                 "inlong group is in init status, cannot be updated");
 
         groupInfo.setVersion(existGroupInfo.getVersion());
         Pair<String, String> idAndErr = groupClient.updateGroup(groupInfo.genRequest());
         String errMsg = idAndErr.getValue();
-        Preconditions.checkNull(errMsg, errMsg);
+        Preconditions.expectNull(errMsg, errMsg);
 
         this.groupContext.setGroupInfo(groupInfo);
     }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongStreamImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongStreamImpl.java
index a592df2ab..947c2958b 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongStreamImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/InlongStreamImpl.java
@@ -167,7 +167,7 @@ public class InlongStreamImpl implements InlongStream {
 
     @Override
     public InlongStream addSource(StreamSource source) {
-        Preconditions.checkNotNull(source.getSourceName(), "source name cannot be null");
+        Preconditions.expectNotNull(source.getSourceName(), "source name cannot be null");
         String sourceName = source.getSourceName();
         if (streamSources.get(sourceName) != null) {
             throw new IllegalArgumentException(String.format("source name=%s has already be set", source));
@@ -178,7 +178,7 @@ public class InlongStreamImpl implements InlongStream {
 
     @Override
     public InlongStream addSink(StreamSink streamSink) {
-        Preconditions.checkNotNull(streamSink.getSinkName(), "sink name cannot be null");
+        Preconditions.expectNotNull(streamSink.getSinkName(), "sink name cannot be null");
         String sinkName = streamSink.getSinkName();
         if (streamSinks.get(sinkName) != null) {
             throw new IllegalArgumentException(String.format("sink name=%s has already be set", streamSink));
@@ -189,7 +189,7 @@ public class InlongStreamImpl implements InlongStream {
 
     @Override
     public InlongStream addTransform(StreamTransform transform) {
-        Preconditions.checkNotNull(transform.getTransformName(), "transform name should not be empty");
+        Preconditions.expectNotNull(transform.getTransformName(), "transform name should not be empty");
         String transformName = transform.getTransformName();
         if (streamTransforms.get(transformName) != null) {
             throw new IllegalArgumentException(String.format("transform name=%s has already be set", transform));
@@ -218,21 +218,21 @@ public class InlongStreamImpl implements InlongStream {
 
     @Override
     public InlongStream updateSource(StreamSource source) {
-        Preconditions.checkNotNull(source.getSourceName(), "source name cannot be null");
+        Preconditions.expectNotNull(source.getSourceName(), "source name cannot be null");
         streamSources.put(source.getSourceName(), source);
         return this;
     }
 
     @Override
     public InlongStream updateSink(StreamSink streamSink) {
-        Preconditions.checkNotNull(streamSink.getSinkName(), "sink name cannot be null");
+        Preconditions.expectNotNull(streamSink.getSinkName(), "sink name cannot be null");
         streamSinks.put(streamSink.getSinkName(), streamSink);
         return this;
     }
 
     @Override
     public InlongStream updateTransform(StreamTransform transform) {
-        Preconditions.checkNotNull(transform.getTransformName(), "transform name cannot be null");
+        Preconditions.expectNotNull(transform.getTransformName(), "transform name cannot be null");
         streamTransforms.put(transform.getTransformName(), transform);
         return this;
     }
@@ -446,7 +446,7 @@ public class InlongStreamImpl implements InlongStream {
 
     @Override
     public StreamSink getSinkInfoById(Integer sinkId) {
-        Preconditions.checkNotNull(sinkId, "sinkId cannot be null");
+        Preconditions.expectNotNull(sinkId, "sinkId cannot be null");
         // Get from cache firstly
         return this.streamSinks.values()
                 .stream()
@@ -458,13 +458,13 @@ public class InlongStreamImpl implements InlongStream {
 
     @Override
     public StreamSink getSinkInfoByName(String sinkName) {
-        Preconditions.checkNotEmpty(sinkName, "sinkName cannot be empty");
+        Preconditions.expectNotEmpty(sinkName, "sinkName cannot be empty");
         return this.streamSinks.get(sinkName);
     }
 
     @Override
     public StreamSource getSourceById(int sourceId) {
-        Preconditions.checkNotNull(sourceId, "sinkId cannot be null");
+        Preconditions.expectNotNull(sourceId, "sinkId cannot be null");
         return this.streamSources.values()
                 .stream()
                 .filter(streamSource -> streamSource.getId().equals(sourceId))
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/NoAuthImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/NoAuthImpl.java
index 6e7dcf8e4..70bbe44d4 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/NoAuthImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/NoAuthImpl.java
@@ -39,10 +39,10 @@ public class NoAuthImpl implements NoAuth {
 
     @Override
     public Integer register(UserRequest request) {
-        Preconditions.checkNotEmpty(request.getName(), "username cannot be empty");
-        Preconditions.checkNotEmpty(request.getPassword(), "password cannot be empty");
-        Preconditions.checkNotNull(request.getAccountType(), "accountType cannot be null");
-        Preconditions.checkNotNull(request.getValidDays(), "validDays cannot be null");
+        Preconditions.expectNotEmpty(request.getName(), "username cannot be empty");
+        Preconditions.expectNotEmpty(request.getPassword(), "password cannot be empty");
+        Preconditions.expectNotNull(request.getAccountType(), "accountType cannot be null");
+        Preconditions.expectNotNull(request.getValidDays(), "validDays cannot be null");
 
         return noAuthClient.register(request);
     }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/StreamSourceImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/StreamSourceImpl.java
index 3ed1a0437..8447a110e 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/StreamSourceImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/StreamSourceImpl.java
@@ -36,8 +36,8 @@ public class StreamSourceImpl implements StreamSource {
 
     @Override
     public Boolean forceDelete(String groupId, String streamId) {
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
         return sourceClient.forceDelete(groupId, streamId);
     }
 }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/UserImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/UserImpl.java
index dc356994b..cd62bd8c7 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/UserImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/UserImpl.java
@@ -43,39 +43,39 @@ public class UserImpl implements User {
 
     @Override
     public Integer register(UserRequest userInfo) {
-        Preconditions.checkNotEmpty(userInfo.getName(), "username cannot be empty");
-        Preconditions.checkNotEmpty(userInfo.getPassword(), "password cannot be empty");
+        Preconditions.expectNotEmpty(userInfo.getName(), "username cannot be empty");
+        Preconditions.expectNotEmpty(userInfo.getPassword(), "password cannot be empty");
         return userClient.register(userInfo);
     }
 
     @Override
     public UserInfo getById(Integer id) {
-        Preconditions.checkNotNull(id, "user id cannot be null");
+        Preconditions.expectNotNull(id, "user id cannot be null");
         return userClient.getById(id);
     }
 
     @Override
     public UserInfo getByName(String name) {
-        Preconditions.checkNotNull(name, "username cannot be null");
+        Preconditions.expectNotNull(name, "username cannot be null");
         return userClient.getByName(name);
     }
 
     @Override
     public PageResult<UserInfo> list(UserRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
+        Preconditions.expectNotNull(request, "request cannot be null");
         return userClient.list(request);
     }
 
     @Override
     public Integer update(UserRequest userInfo) {
-        Preconditions.checkNotNull(userInfo, "userinfo cannot be null");
-        Preconditions.checkNotNull(userInfo.getId(), "user id cannot be null");
+        Preconditions.expectNotNull(userInfo, "userinfo cannot be null");
+        Preconditions.expectNotNull(userInfo.getId(), "user id cannot be null");
         return userClient.update(userInfo);
     }
 
     @Override
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "user id cannot be null");
+        Preconditions.expectNotNull(id, "user id cannot be null");
         return userClient.delete(id);
     }
 }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/WorkflowImpl.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/WorkflowImpl.java
index f86cc028b..7bfc629aa 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/WorkflowImpl.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/impl/WorkflowImpl.java
@@ -43,50 +43,50 @@ public class WorkflowImpl implements Workflow {
 
     @Override
     public WorkflowResult start(WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(request.getName(), "process name cannot be null");
-        Preconditions.checkNotNull(request.getForm(), "form cannot be null");
+        Preconditions.expectNotNull(request.getName(), "process name cannot be null");
+        Preconditions.expectNotNull(request.getForm(), "form cannot be null");
         return workflowClient.start(request);
     }
 
     @Override
     public WorkflowResult cancel(Integer processId, WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(processId, "process id cannot be null");
+        Preconditions.expectNotNull(processId, "process id cannot be null");
         return workflowClient.cancel(processId, request);
     }
 
     @Override
     public WorkflowResult continueProcess(Integer processId, WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(processId, "process id cannot be null");
+        Preconditions.expectNotNull(processId, "process id cannot be null");
         return workflowClient.continueProcess(processId, request);
     }
 
     @Override
     public WorkflowResult reject(Integer taskId, WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(taskId, "task id cannot be null");
+        Preconditions.expectNotNull(taskId, "task id cannot be null");
         return workflowClient.reject(taskId, request);
     }
 
     @Override
     public WorkflowResult complete(Integer taskId, WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(taskId, "task id cannot be null");
+        Preconditions.expectNotNull(taskId, "task id cannot be null");
         return workflowClient.complete(taskId, request);
     }
 
     @Override
     public ProcessDetailResponse detail(Integer processId, Integer taskId) {
-        Preconditions.checkNotNull(processId, "process id cannot be null");
+        Preconditions.expectNotNull(processId, "process id cannot be null");
         return workflowClient.detail(processId, taskId);
     }
 
     @Override
     public PageResult<ProcessResponse> listProcess(ProcessRequest request) {
-        Preconditions.checkNotNull(request, "process request cannot be null");
+        Preconditions.expectNotNull(request, "process request cannot be null");
         return workflowClient.listProcess(request);
     }
 
     @Override
     public PageResult<TaskResponse> listTask(TaskRequest request) {
-        Preconditions.checkNotNull(request, "task request cannot be null");
+        Preconditions.expectNotNull(request, "task request cannot be null");
         return workflowClient.listTask(request);
     }
 }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/InnerGroupContext.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/InnerGroupContext.java
index 5ef8c48b8..4f3c15998 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/InnerGroupContext.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/InnerGroupContext.java
@@ -44,12 +44,12 @@ public class InnerGroupContext {
     private ApplyGroupProcessForm initMsg;
 
     public String getGroupId() {
-        Preconditions.checkNotNull(groupInfo, "inlong group info was not init");
+        Preconditions.expectNotNull(groupInfo, "inlong group info was not init");
         return groupInfo.getInlongGroupId();
     }
 
     public void setStreamContext(InnerStreamContext streamContext) {
-        Preconditions.checkTrue(streamContext != null && streamContext.getStreamInfo() != null,
+        Preconditions.expectTrue(streamContext != null && streamContext.getStreamInfo() != null,
                 "stream context cannot be null");
         if (MapUtils.isEmpty(streamContextMap)) {
             streamContextMap = Maps.newHashMap();
@@ -58,7 +58,7 @@ public class InnerGroupContext {
     }
 
     public void setStream(InlongStream stream) {
-        Preconditions.checkTrue(stream != null, "stream cannot be null");
+        Preconditions.expectTrue(stream != null, "stream cannot be null");
         if (MapUtils.isEmpty(streamMap)) {
             streamMap = Maps.newHashMap();
         }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/DataNodeClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/DataNodeClient.java
index c89cec12e..ffaeab805 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/DataNodeClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/DataNodeClient.java
@@ -45,9 +45,9 @@ public class DataNodeClient {
      * @return cluster id after saving
      */
     public Integer save(DataNodeRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
-        Preconditions.checkNotEmpty(request.getName(), "data node name cannot be empty");
-        Preconditions.checkNotEmpty(request.getType(), "data node type cannot be empty");
+        Preconditions.expectNotNull(request, "request cannot be null");
+        Preconditions.expectNotEmpty(request.getName(), "data node name cannot be empty");
+        Preconditions.expectNotEmpty(request.getType(), "data node type cannot be empty");
         Response<Integer> response = ClientUtils.executeHttpCall(dataNodeApi.save(request));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -60,7 +60,7 @@ public class DataNodeClient {
      * @return node info
      */
     public DataNodeInfo get(Integer id) {
-        Preconditions.checkNotNull(id, "data node id cannot be null");
+        Preconditions.expectNotNull(id, "data node id cannot be null");
         Response<DataNodeInfo> response = ClientUtils.executeHttpCall(dataNodeApi.get(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -73,7 +73,7 @@ public class DataNodeClient {
      * @return node list
      */
     public PageResult<DataNodeInfo> list(DataNodeRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
+        Preconditions.expectNotNull(request, "request cannot be null");
         Response<PageResult<DataNodeInfo>> response = ClientUtils.executeHttpCall(dataNodeApi.list(request));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -86,10 +86,10 @@ public class DataNodeClient {
      * @return whether succeed
      */
     public Boolean update(DataNodeRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
-        Preconditions.checkNotEmpty(request.getName(), "data node name cannot be empty");
-        Preconditions.checkNotEmpty(request.getType(), "data node type cannot be empty");
-        Preconditions.checkNotNull(request.getId(), "data node id cannot be null");
+        Preconditions.expectNotNull(request, "request cannot be null");
+        Preconditions.expectNotEmpty(request.getName(), "data node name cannot be empty");
+        Preconditions.expectNotEmpty(request.getType(), "data node type cannot be empty");
+        Preconditions.expectNotNull(request.getId(), "data node id cannot be null");
         Response<Boolean> response = ClientUtils.executeHttpCall(dataNodeApi.update(request));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -102,9 +102,9 @@ public class DataNodeClient {
      * @return update result
      */
     public UpdateResult updateByKey(DataNodeRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
-        Preconditions.checkNotEmpty(request.getName(), "data node name cannot be empty");
-        Preconditions.checkNotEmpty(request.getType(), "data node type cannot be empty");
+        Preconditions.expectNotNull(request, "request cannot be null");
+        Preconditions.expectNotEmpty(request.getName(), "data node name cannot be empty");
+        Preconditions.expectNotEmpty(request.getType(), "data node type cannot be empty");
         Response<UpdateResult> response = ClientUtils.executeHttpCall(dataNodeApi.updateByKey(request));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -117,7 +117,7 @@ public class DataNodeClient {
      * @return whether succeed
      */
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "data node id cannot be null");
+        Preconditions.expectNotNull(id, "data node id cannot be null");
         Response<Boolean> response = ClientUtils.executeHttpCall(dataNodeApi.delete(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -131,8 +131,8 @@ public class DataNodeClient {
      * @return whether succeed
      */
     public Boolean deleteByKey(String name, String type) {
-        Preconditions.checkNotEmpty(name, "data node name cannot be empty or null");
-        Preconditions.checkNotEmpty(type, "data node type cannot be empty or null");
+        Preconditions.expectNotEmpty(name, "data node name cannot be empty or null");
+        Preconditions.expectNotEmpty(type, "data node type cannot be empty or null");
         Response<Boolean> response = ClientUtils.executeHttpCall(dataNodeApi.deleteByKey(name, type));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/HeartbeatClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/HeartbeatClient.java
index d8af81a2f..3a040bf18 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/HeartbeatClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/HeartbeatClient.java
@@ -48,9 +48,9 @@ public class HeartbeatClient {
      * @return component heartbeat
      */
     public ComponentHeartbeatResponse getComponentHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
 
         Response<ComponentHeartbeatResponse> response = ClientUtils.executeHttpCall(
                 heartbeatApi.getComponentHeartbeat(request));
@@ -65,10 +65,10 @@ public class HeartbeatClient {
      * @return group heartbeat
      */
     public GroupHeartbeatResponse getGroupHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         Response<GroupHeartbeatResponse> response = ClientUtils.executeHttpCall(
                 heartbeatApi.getGroupHeartbeat(request));
@@ -83,11 +83,11 @@ public class HeartbeatClient {
      * @return stream heartbeat
      */
     public StreamHeartbeatResponse getStreamHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongStreamId(), ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInlongStreamId(), ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         Response<StreamHeartbeatResponse> response = ClientUtils.executeHttpCall(
                 heartbeatApi.getStreamHeartbeat(request));
@@ -102,8 +102,8 @@ public class HeartbeatClient {
      * @return list of component heartbeat
      */
     public PageResult<ComponentHeartbeatResponse> listComponentHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
 
         Response<PageResult<ComponentHeartbeatResponse>> response = ClientUtils.executeHttpCall(
                 heartbeatApi.listComponentHeartbeat(request));
@@ -118,8 +118,8 @@ public class HeartbeatClient {
      * @return list of group heartbeat
      */
     public PageResult<GroupHeartbeatResponse> listGroupHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
 
         Response<PageResult<GroupHeartbeatResponse>> response = ClientUtils.executeHttpCall(
                 heartbeatApi.listGroupHeartbeat(request));
@@ -134,9 +134,9 @@ public class HeartbeatClient {
      * @return list of stream heartbeat
      */
     public PageResult<StreamHeartbeatResponse> listStreamHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getComponent(), ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         Response<PageResult<StreamHeartbeatResponse>> response = ClientUtils.executeHttpCall(
                 heartbeatApi.listStreamHeartbeat(request));
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongClusterClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongClusterClient.java
index 7140bf595..604e40a48 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongClusterClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongClusterClient.java
@@ -66,7 +66,7 @@ public class InlongClusterClient {
      * @return cluster tag info
      */
     public ClusterTagResponse getTag(Integer id) {
-        Preconditions.checkNotNull(id, "cluster id should not be empty");
+        Preconditions.expectNotNull(id, "cluster id should not be empty");
         Response<ClusterTagResponse> response = ClientUtils.executeHttpCall(inlongClusterApi.getTag(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -104,7 +104,7 @@ public class InlongClusterClient {
      * @return whether succeed
      */
     public Boolean deleteTag(Integer id) {
-        Preconditions.checkNotNull(id, "cluster id should not be empty");
+        Preconditions.expectNotNull(id, "cluster id should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongClusterApi.deleteTag(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -117,9 +117,9 @@ public class InlongClusterClient {
      * @return clusterIndex
      */
     public Integer saveCluster(ClusterRequest request) {
-        Preconditions.checkNotEmpty(request.getName(), "cluster name should not be empty");
-        Preconditions.checkNotEmpty(request.getType(), "cluster type should not be empty");
-        Preconditions.checkNotEmpty(request.getClusterTags(), "cluster tags should not be empty");
+        Preconditions.expectNotEmpty(request.getName(), "cluster name should not be empty");
+        Preconditions.expectNotEmpty(request.getType(), "cluster type should not be empty");
+        Preconditions.expectNotEmpty(request.getClusterTags(), "cluster tags should not be empty");
         Response<Integer> clusterIndexResponse = ClientUtils.executeHttpCall(inlongClusterApi.save(request));
         ClientUtils.assertRespSuccess(clusterIndexResponse);
         return clusterIndexResponse.getData();
@@ -132,7 +132,7 @@ public class InlongClusterClient {
      * @return cluster info
      */
     public ClusterInfo get(Integer id) {
-        Preconditions.checkNotNull(id, "cluster id should not be empty");
+        Preconditions.expectNotNull(id, "cluster id should not be empty");
         Response<ClusterInfo> clusterInfoResponse = ClientUtils.executeHttpCall(inlongClusterApi.get(id));
         ClientUtils.assertRespSuccess(clusterInfoResponse);
         return clusterInfoResponse.getData();
@@ -157,7 +157,7 @@ public class InlongClusterClient {
      * @return whether succeed
      */
     public Boolean update(ClusterRequest request) {
-        Preconditions.checkNotNull(request.getId(), "inlong cluster id cannot be empty");
+        Preconditions.expectNotNull(request.getId(), "inlong cluster id cannot be empty");
 
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongClusterApi.update(request));
         ClientUtils.assertRespSuccess(response);
@@ -172,8 +172,8 @@ public class InlongClusterClient {
      * @return update result
      */
     public UpdateResult updateByKey(ClusterRequest request) {
-        Preconditions.checkNotNull(request.getName(), "cluster name should not be null");
-        Preconditions.checkNotNull(request.getType(), "cluster type should not be null");
+        Preconditions.expectNotNull(request.getName(), "cluster name should not be null");
+        Preconditions.expectNotNull(request.getType(), "cluster type should not be null");
         Response<UpdateResult> response = ClientUtils.executeHttpCall(inlongClusterApi.updateByKey(request));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -198,7 +198,7 @@ public class InlongClusterClient {
      * @return whether succeed
      */
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "cluster id should not be empty");
+        Preconditions.expectNotNull(id, "cluster id should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongClusterApi.delete(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -212,8 +212,8 @@ public class InlongClusterClient {
      * @return wheter succeed
      */
     public Boolean deleteByKey(String name, String type) {
-        Preconditions.checkNotNull(name, "cluster name should not be empty");
-        Preconditions.checkNotNull(type, "cluster type should not be empty");
+        Preconditions.expectNotNull(name, "cluster name should not be empty");
+        Preconditions.expectNotNull(type, "cluster type should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongClusterApi.deleteByKey(name, type));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -238,7 +238,7 @@ public class InlongClusterClient {
      * @return cluster info
      */
     public ClusterNodeResponse getNode(Integer id) {
-        Preconditions.checkNotNull(id, "cluster id should not be empty");
+        Preconditions.expectNotNull(id, "cluster id should not be empty");
         Response<ClusterNodeResponse> response = ClientUtils.executeHttpCall(inlongClusterApi.getNode(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -291,7 +291,7 @@ public class InlongClusterClient {
      * @return whether succeed
      */
     public Boolean deleteNode(Integer id) {
-        Preconditions.checkNotNull(id, "cluster id should not be empty");
+        Preconditions.expectNotNull(id, "cluster id should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongClusterApi.deleteNode(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongConsumeClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongConsumeClient.java
index 36ba6389b..7090acdd3 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongConsumeClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongConsumeClient.java
@@ -52,9 +52,9 @@ public class InlongConsumeClient {
      * @return inlong consume id after saving
      */
     public Integer save(InlongConsumeRequest request) {
-        Preconditions.checkNotNull(request, "inlong consume request cannot be null");
-        Preconditions.checkNotNull(request.getTopic(), "inlong consume topic cannot be null");
-        Preconditions.checkNotNull(request.getConsumerGroup(), "inlong consume topic cannot be null");
+        Preconditions.expectNotNull(request, "inlong consume request cannot be null");
+        Preconditions.expectNotNull(request.getTopic(), "inlong consume topic cannot be null");
+        Preconditions.expectNotNull(request.getConsumerGroup(), "inlong consume topic cannot be null");
 
         Response<Integer> response = ClientUtils.executeHttpCall(inlongConsumeApi.save(request));
         ClientUtils.assertRespSuccess(response);
@@ -68,7 +68,7 @@ public class InlongConsumeClient {
      * @return detail of inlong group
      */
     public InlongConsumeInfo get(Integer id) {
-        Preconditions.checkNotNull(id, "inlong consume id cannot be null");
+        Preconditions.expectNotNull(id, "inlong consume id cannot be null");
 
         Response<InlongConsumeInfo> response = ClientUtils.executeHttpCall(inlongConsumeApi.get(id));
         ClientUtils.assertRespSuccess(response);
@@ -110,7 +110,7 @@ public class InlongConsumeClient {
      * @return inlong consume id after saving
      */
     public Integer update(InlongConsumeRequest request) {
-        Preconditions.checkNotNull(request, "inlong consume request cannot be null");
+        Preconditions.expectNotNull(request, "inlong consume request cannot be null");
 
         Response<Integer> response = ClientUtils.executeHttpCall(inlongConsumeApi.update(request));
         ClientUtils.assertRespSuccess(response);
@@ -124,7 +124,7 @@ public class InlongConsumeClient {
      * @return whether succeed
      */
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "inlong consume id cannot be null");
+        Preconditions.expectNotNull(id, "inlong consume id cannot be null");
 
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongConsumeApi.delete(id));
         ClientUtils.assertRespSuccess(response);
@@ -138,7 +138,7 @@ public class InlongConsumeClient {
      * @return workflow result
      */
     public WorkflowResult startProcess(Integer id) {
-        Preconditions.checkNotNull(id, "inlong consume id cannot be null");
+        Preconditions.expectNotNull(id, "inlong consume id cannot be null");
 
         Response<WorkflowResult> response = ClientUtils.executeHttpCall(inlongConsumeApi.startProcess(id));
         ClientUtils.assertRespSuccess(response);
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongGroupClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongGroupClient.java
index 290793d2e..d1e011f93 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongGroupClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongGroupClient.java
@@ -64,7 +64,7 @@ public class InlongGroupClient {
      * Check whether a group exists based on the group ID.
      */
     public Boolean isGroupExists(String inlongGroupId) {
-        Preconditions.checkNotEmpty(inlongGroupId, "InlongGroupId should not be empty");
+        Preconditions.expectNotEmpty(inlongGroupId, "InlongGroupId should not be empty");
 
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongGroupApi.isGroupExists(inlongGroupId));
         ClientUtils.assertRespSuccess(response);
@@ -89,7 +89,7 @@ public class InlongGroupClient {
      */
     @SneakyThrows
     public InlongGroupInfo getGroupInfo(String inlongGroupId) {
-        Preconditions.checkNotEmpty(inlongGroupId, "InlongGroupId should not be empty");
+        Preconditions.expectNotEmpty(inlongGroupId, "InlongGroupId should not be empty");
 
         Response<Object> responseBody = ClientUtils.executeHttpCall(inlongGroupApi.getGroupInfo(inlongGroupId));
         if (responseBody.isSuccess()) {
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongStreamClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongStreamClient.java
index 21115a0e9..3d34c400e 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongStreamClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/InlongStreamClient.java
@@ -59,8 +59,8 @@ public class InlongStreamClient {
     public Boolean isStreamExists(InlongStreamInfo streamInfo) {
         final String groupId = streamInfo.getInlongGroupId();
         final String streamId = streamInfo.getInlongStreamId();
-        Preconditions.checkNotEmpty(groupId, "InlongGroupId should not be empty");
-        Preconditions.checkNotEmpty(streamId, "InlongStreamId should not be empty");
+        Preconditions.expectNotEmpty(groupId, "InlongGroupId should not be empty");
+        Preconditions.expectNotEmpty(streamId, "InlongStreamId should not be empty");
 
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongStreamApi.isStreamExists(groupId, streamId));
         ClientUtils.assertRespSuccess(response);
@@ -146,8 +146,8 @@ public class InlongStreamClient {
      * @return whether succeed
      */
     public boolean startProcess(String groupId, String streamId) {
-        Preconditions.checkNotEmpty(groupId, "InlongGroupId should not be empty");
-        Preconditions.checkNotEmpty(streamId, "InlongStreamId should not be empty");
+        Preconditions.expectNotEmpty(groupId, "InlongGroupId should not be empty");
+        Preconditions.expectNotEmpty(streamId, "InlongStreamId should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongStreamApi.startProcess(groupId, streamId));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -161,8 +161,8 @@ public class InlongStreamClient {
      * @return whether succeed
      */
     public boolean suspendProcess(String groupId, String streamId) {
-        Preconditions.checkNotEmpty(groupId, "InlongGroupId should not be empty");
-        Preconditions.checkNotEmpty(streamId, "InlongStreamId should not be empty");
+        Preconditions.expectNotEmpty(groupId, "InlongGroupId should not be empty");
+        Preconditions.expectNotEmpty(streamId, "InlongStreamId should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongStreamApi.suspendProcess(groupId, streamId));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -176,8 +176,8 @@ public class InlongStreamClient {
      * @return whether succeed
      */
     public boolean restartProcess(String groupId, String streamId) {
-        Preconditions.checkNotEmpty(groupId, "InlongGroupId should not be empty");
-        Preconditions.checkNotEmpty(streamId, "InlongStreamId should not be empty");
+        Preconditions.expectNotEmpty(groupId, "InlongGroupId should not be empty");
+        Preconditions.expectNotEmpty(streamId, "InlongStreamId should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongStreamApi.restartProcess(groupId, streamId));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -191,8 +191,8 @@ public class InlongStreamClient {
      * @return whether succeed
      */
     public boolean deleteProcess(String groupId, String streamId) {
-        Preconditions.checkNotEmpty(groupId, "InlongGroupId should not be empty");
-        Preconditions.checkNotEmpty(streamId, "InlongStreamId should not be empty");
+        Preconditions.expectNotEmpty(groupId, "InlongGroupId should not be empty");
+        Preconditions.expectNotEmpty(streamId, "InlongStreamId should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongStreamApi.deleteProcess(groupId, streamId));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -206,8 +206,8 @@ public class InlongStreamClient {
      * @return whether succeed
      */
     public boolean delete(String groupId, String streamId) {
-        Preconditions.checkNotEmpty(groupId, "InlongGroupId should not be empty");
-        Preconditions.checkNotEmpty(streamId, "InlongStreamId should not be empty");
+        Preconditions.expectNotEmpty(groupId, "InlongGroupId should not be empty");
+        Preconditions.expectNotEmpty(streamId, "InlongStreamId should not be empty");
         Response<Boolean> response = ClientUtils.executeHttpCall(inlongStreamApi.delete(groupId, streamId));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/NoAuthClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/NoAuthClient.java
index c427ff9dd..565453aab 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/NoAuthClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/NoAuthClient.java
@@ -42,10 +42,10 @@ public class NoAuthClient {
      * @return user id after saving
      */
     public Integer register(UserRequest request) {
-        Preconditions.checkNotEmpty(request.getName(), "username cannot be empty");
-        Preconditions.checkNotEmpty(request.getPassword(), "password cannot be empty");
-        Preconditions.checkNotNull(request.getAccountType(), "accountType cannot be null");
-        Preconditions.checkNotNull(request.getValidDays(), "validDays cannot be null");
+        Preconditions.expectNotEmpty(request.getName(), "username cannot be empty");
+        Preconditions.expectNotEmpty(request.getPassword(), "password cannot be empty");
+        Preconditions.expectNotNull(request.getAccountType(), "accountType cannot be null");
+        Preconditions.expectNotNull(request.getValidDays(), "validDays cannot be null");
 
         Response<Integer> response = ClientUtils.executeHttpCall(noAuthApi.register(request));
         ClientUtils.assertRespSuccess(response);
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamSinkClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamSinkClient.java
index 8a8e841f9..5676bf18c 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamSinkClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamSinkClient.java
@@ -51,7 +51,7 @@ public class StreamSinkClient {
      * Delete stream sink info by ID.
      */
     public boolean deleteSink(int id) {
-        Preconditions.checkTrue(id > 0, "sinkId is illegal");
+        Preconditions.expectTrue(id > 0, "sinkId is illegal");
         Response<Boolean> response = ClientUtils.executeHttpCall(streamSinkApi.deleteById(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamSourceClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamSourceClient.java
index f98635066..162ec11ae 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamSourceClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamSourceClient.java
@@ -83,7 +83,7 @@ public class StreamSourceClient {
      * Delete data source information by id.
      */
     public boolean deleteSource(int id) {
-        Preconditions.checkTrue(id > 0, "sourceId is illegal");
+        Preconditions.expectTrue(id > 0, "sourceId is illegal");
         Response<Boolean> response = ClientUtils.executeHttpCall(streamSourceApi.deleteSource(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
@@ -97,8 +97,8 @@ public class StreamSourceClient {
      * @return Whether succeed
      */
     public boolean forceDelete(String groupId, String streamId) {
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         Response<Boolean> response = ClientUtils.executeHttpCall(streamSourceApi.forceDelete(groupId, streamId));
         ClientUtils.assertRespSuccess(response);
@@ -106,7 +106,7 @@ public class StreamSourceClient {
     }
 
     public StreamSource get(int id) {
-        Preconditions.checkTrue(id > 0, "sourceId is illegal");
+        Preconditions.expectTrue(id > 0, "sourceId is illegal");
         Response<StreamSource> response = ClientUtils.executeHttpCall(streamSourceApi.get(id));
         ClientUtils.assertRespSuccess(response);
         return response.getData();
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamTransformClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamTransformClient.java
index 38543953c..6aa755356 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamTransformClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/StreamTransformClient.java
@@ -75,9 +75,9 @@ public class StreamTransformClient {
      * Delete conversion function info.
      */
     public boolean deleteTransform(TransformRequest transformRequest) {
-        Preconditions.checkNotEmpty(transformRequest.getInlongGroupId(), "inlongGroupId should not be null");
-        Preconditions.checkNotEmpty(transformRequest.getInlongStreamId(), "inlongStreamId should not be null");
-        Preconditions.checkNotEmpty(transformRequest.getTransformName(), "transformName should not be null");
+        Preconditions.expectNotEmpty(transformRequest.getInlongGroupId(), "inlongGroupId should not be null");
+        Preconditions.expectNotEmpty(transformRequest.getInlongStreamId(), "inlongStreamId should not be null");
+        Preconditions.expectNotEmpty(transformRequest.getTransformName(), "transformName should not be null");
 
         Response<Boolean> response = ClientUtils.executeHttpCall(
                 streamTransformApi.deleteTransform(transformRequest.getInlongGroupId(),
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/UserClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/UserClient.java
index adb64b190..1d9f591ae 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/UserClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/UserClient.java
@@ -55,8 +55,8 @@ public class UserClient {
      * @return user id after saving
      */
     public Integer register(UserRequest userInfo) {
-        Preconditions.checkNotEmpty(userInfo.getName(), "username cannot be empty");
-        Preconditions.checkNotEmpty(userInfo.getPassword(), "password cannot be empty");
+        Preconditions.expectNotEmpty(userInfo.getName(), "username cannot be empty");
+        Preconditions.expectNotEmpty(userInfo.getPassword(), "password cannot be empty");
 
         Response<Integer> response = ClientUtils.executeHttpCall(userApi.register(userInfo));
         ClientUtils.assertRespSuccess(response);
@@ -70,7 +70,7 @@ public class UserClient {
      * @return user info
      */
     public UserInfo getById(Integer id) {
-        Preconditions.checkNotNull(id, "user id cannot be null");
+        Preconditions.expectNotNull(id, "user id cannot be null");
 
         Response<UserInfo> response = ClientUtils.executeHttpCall(userApi.getById(id));
         ClientUtils.assertRespSuccess(response);
@@ -84,7 +84,7 @@ public class UserClient {
      * @return user info
      */
     public UserInfo getByName(String name) {
-        Preconditions.checkNotNull(name, "username cannot be null");
+        Preconditions.expectNotNull(name, "username cannot be null");
 
         Response<UserInfo> response = ClientUtils.executeHttpCall(userApi.getByName(name));
         ClientUtils.assertRespSuccess(response);
@@ -98,7 +98,7 @@ public class UserClient {
      * @return user info list
      */
     public PageResult<UserInfo> list(UserRequest request) {
-        Preconditions.checkNotNull(request, "request cannot be null");
+        Preconditions.expectNotNull(request, "request cannot be null");
 
         Response<PageResult<UserInfo>> response = ClientUtils.executeHttpCall(userApi.list(request));
         ClientUtils.assertRespSuccess(response);
@@ -112,8 +112,8 @@ public class UserClient {
      * @return user id
      */
     public Integer update(UserRequest userInfo) {
-        Preconditions.checkNotNull(userInfo, "userinfo cannot be null");
-        Preconditions.checkNotNull(userInfo.getId(), "user id cannot be null");
+        Preconditions.expectNotNull(userInfo, "userinfo cannot be null");
+        Preconditions.expectNotNull(userInfo.getId(), "user id cannot be null");
 
         Response<Integer> response = ClientUtils.executeHttpCall(userApi.update(userInfo));
         ClientUtils.assertRespSuccess(response);
@@ -127,7 +127,7 @@ public class UserClient {
      * @return whether succeed
      */
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "user id cannot be null");
+        Preconditions.expectNotNull(id, "user id cannot be null");
 
         Response<Boolean> response = ClientUtils.executeHttpCall(userApi.delete(id));
         ClientUtils.assertRespSuccess(response);
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowApproverClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowApproverClient.java
index 7c8ac4505..161a46740 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowApproverClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowApproverClient.java
@@ -52,9 +52,9 @@ public class WorkflowApproverClient {
      * @param request approver request
      */
     public Integer save(ApproverRequest request) {
-        Preconditions.checkNotEmpty(request.getProcessName(), "process name cannot be empty");
-        Preconditions.checkNotEmpty(request.getTaskName(), "task name cannot be empty");
-        Preconditions.checkNotEmpty(request.getApprovers(), "approvers cannot be empty");
+        Preconditions.expectNotEmpty(request.getProcessName(), "process name cannot be empty");
+        Preconditions.expectNotEmpty(request.getTaskName(), "task name cannot be empty");
+        Preconditions.expectNotEmpty(request.getApprovers(), "approvers cannot be empty");
 
         Response<Integer> response = ClientUtils.executeHttpCall(workflowApproverApi.save(request));
         ClientUtils.assertRespSuccess(response);
@@ -69,7 +69,7 @@ public class WorkflowApproverClient {
      * @return approver info
      */
     public ApproverResponse get(Integer id) {
-        Preconditions.checkNotNull(id, "id cannot be null");
+        Preconditions.expectNotNull(id, "id cannot be null");
 
         Response<ApproverResponse> response = ClientUtils.executeHttpCall(workflowApproverApi.get(id));
         ClientUtils.assertRespSuccess(response);
@@ -84,8 +84,8 @@ public class WorkflowApproverClient {
      * @return approver list
      */
     public List<ApproverResponse> listByCondition(ApproverPageRequest request) {
-        Preconditions.checkNotNull(request.getPageNum(), "page num cannot be null");
-        Preconditions.checkNotNull(request.getPageSize(), "page size cannot be null");
+        Preconditions.expectNotNull(request.getPageNum(), "page num cannot be null");
+        Preconditions.expectNotNull(request.getPageSize(), "page size cannot be null");
 
         Map<String, Object> requestMap = JsonUtils.OBJECT_MAPPER.convertValue(request,
                 new TypeReference<Map<String, Object>>() {
@@ -103,7 +103,7 @@ public class WorkflowApproverClient {
      * @param id approver id
      */
     public Boolean delete(Integer id) {
-        Preconditions.checkNotNull(id, "id cannot be null");
+        Preconditions.expectNotNull(id, "id cannot be null");
 
         Response<Boolean> response = ClientUtils.executeHttpCall(workflowApproverApi.delete(id));
         ClientUtils.assertRespSuccess(response);
@@ -117,7 +117,7 @@ public class WorkflowApproverClient {
      * @param request approver request
      */
     public Integer update(ApproverRequest request) {
-        Preconditions.checkNotNull(request.getId(), "id cannot be null");
+        Preconditions.expectNotNull(request.getId(), "id cannot be null");
 
         Response<Integer> response = ClientUtils.executeHttpCall(workflowApproverApi.update(request));
         ClientUtils.assertRespSuccess(response);
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowClient.java
index 11f57c7e2..c2ddae6d3 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowClient.java
@@ -88,8 +88,8 @@ public class WorkflowClient {
      * @return workflow result info
      */
     public WorkflowResult start(WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(request.getName(), "process name cannot be null");
-        Preconditions.checkNotNull(request.getForm(), "form cannot be null");
+        Preconditions.expectNotNull(request.getName(), "process name cannot be null");
+        Preconditions.expectNotNull(request.getForm(), "form cannot be null");
 
         Response<WorkflowResult> response = ClientUtils.executeHttpCall(workflowApi.start(request));
         ClientUtils.assertRespSuccess(response);
@@ -104,7 +104,7 @@ public class WorkflowClient {
      * @return workflow result info
      */
     public WorkflowResult cancel(Integer processId, WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(processId, "process id cannot be null");
+        Preconditions.expectNotNull(processId, "process id cannot be null");
 
         Response<WorkflowResult> response = ClientUtils.executeHttpCall(workflowApi.cancel(processId, request));
         ClientUtils.assertRespSuccess(response);
@@ -119,7 +119,7 @@ public class WorkflowClient {
      * @return workflow result info
      */
     public WorkflowResult continueProcess(Integer processId, WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(processId, "process id cannot be null");
+        Preconditions.expectNotNull(processId, "process id cannot be null");
 
         Response<WorkflowResult> response = ClientUtils.executeHttpCall(
                 workflowApi.continueProcess(processId, request));
@@ -135,7 +135,7 @@ public class WorkflowClient {
      * @return workflow result info
      */
     public WorkflowResult reject(Integer taskId, WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(taskId, "task id cannot be null");
+        Preconditions.expectNotNull(taskId, "task id cannot be null");
 
         Response<WorkflowResult> response = ClientUtils.executeHttpCall(workflowApi.reject(taskId, request));
         ClientUtils.assertRespSuccess(response);
@@ -150,7 +150,7 @@ public class WorkflowClient {
      * @return workflow result info
      */
     public WorkflowResult complete(Integer taskId, WorkflowOperationRequest request) {
-        Preconditions.checkNotNull(taskId, "task id cannot be null");
+        Preconditions.expectNotNull(taskId, "task id cannot be null");
 
         Response<WorkflowResult> response = ClientUtils.executeHttpCall(workflowApi.complete(taskId, request));
         ClientUtils.assertRespSuccess(response);
@@ -165,7 +165,7 @@ public class WorkflowClient {
      * @return process detail response
      */
     public ProcessDetailResponse detail(Integer processId, Integer taskId) {
-        Preconditions.checkNotNull(processId, "process id cannot be null");
+        Preconditions.expectNotNull(processId, "process id cannot be null");
 
         Response<ProcessDetailResponse> response = ClientUtils.executeHttpCall(workflowApi.detail(processId, taskId));
         ClientUtils.assertRespSuccess(response);
@@ -179,7 +179,7 @@ public class WorkflowClient {
      * @return process response list
      */
     public PageResult<ProcessResponse> listProcess(ProcessRequest request) {
-        Preconditions.checkNotNull(request, "process request cannot be null");
+        Preconditions.expectNotNull(request, "process request cannot be null");
 
         Map<String, Object> requestMap = JsonUtils.OBJECT_MAPPER.convertValue(request,
                 new TypeReference<Map<String, Object>>() {
@@ -197,7 +197,7 @@ public class WorkflowClient {
      * @return task response list
      */
     public PageResult<TaskResponse> listTask(TaskRequest request) {
-        Preconditions.checkNotNull(request, "task request cannot be null");
+        Preconditions.expectNotNull(request, "task request cannot be null");
 
         Map<String, Object> requestMap = JsonUtils.OBJECT_MAPPER.convertValue(request,
                 new TypeReference<Map<String, Object>>() {
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowEventClient.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowEventClient.java
index 843d21a7c..ae2a32a9c 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowEventClient.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/inner/client/WorkflowEventClient.java
@@ -66,7 +66,7 @@ public class WorkflowEventClient {
      * Execute the listener based on the event log ID
      */
     public void executeEventListener(Integer id) {
-        Preconditions.checkNotNull(id, "event id cannot be null");
+        Preconditions.expectNotNull(id, "event id cannot be null");
 
         Response<Object> response = ClientUtils.executeHttpCall(workflowEventApi.executeEventListener(id));
         ClientUtils.assertRespSuccess(response);
@@ -76,8 +76,8 @@ public class WorkflowEventClient {
      * Re-execute the specified listener based on the process ID
      */
     public void executeProcessEventListener(Integer processId, String listenerName) {
-        Preconditions.checkNotNull(processId, "processId cannot be null");
-        Preconditions.checkNotEmpty(listenerName, "listenerName cannot be null");
+        Preconditions.expectNotNull(processId, "processId cannot be null");
+        Preconditions.expectNotEmpty(listenerName, "listenerName cannot be null");
 
         Response<Object> response = ClientUtils.executeHttpCall(
                 workflowEventApi.executeProcessEventListener(processId, listenerName));
@@ -88,8 +88,8 @@ public class WorkflowEventClient {
      * Re-execute the specified listener based on the task ID
      */
     public void executeTaskEventListener(Integer taskId, String listenerName) {
-        Preconditions.checkNotNull(taskId, "taskId cannot be null");
-        Preconditions.checkNotEmpty(listenerName, "listenerName cannot be null");
+        Preconditions.expectNotNull(taskId, "taskId cannot be null");
+        Preconditions.expectNotEmpty(listenerName, "listenerName cannot be null");
 
         Response<Object> response = ClientUtils.executeHttpCall(
                 workflowEventApi.executeTaskEventListener(taskId, listenerName));
@@ -100,8 +100,8 @@ public class WorkflowEventClient {
      * Re-trigger the process event based on the process ID
      */
     public void triggerProcessEvent(Integer processId, ProcessEvent processEvent) {
-        Preconditions.checkNotNull(processId, "processId cannot be null");
-        Preconditions.checkNotNull(processEvent, "processEvent cannot be null");
+        Preconditions.expectNotNull(processId, "processId cannot be null");
+        Preconditions.expectNotNull(processEvent, "processEvent cannot be null");
 
         Response<Object> response = ClientUtils.executeHttpCall(
                 workflowEventApi.triggerProcessEvent(processId, processEvent));
@@ -112,8 +112,8 @@ public class WorkflowEventClient {
      * Re-trigger the process event based on the task ID
      */
     public void triggerTaskEvent(Integer processId, TaskEvent taskEvent) {
-        Preconditions.checkNotNull(processId, "processId cannot be null");
-        Preconditions.checkNotNull(taskEvent, "taskEvent cannot be null");
+        Preconditions.expectNotNull(processId, "processId cannot be null");
+        Preconditions.expectNotNull(taskEvent, "taskEvent cannot be null");
 
         Response<Object> response = ClientUtils.executeHttpCall(
                 workflowEventApi.triggerTaskEvent(processId, taskEvent));
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/transform/MultiDependencyTransform.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/transform/MultiDependencyTransform.java
index f47515704..c44835a1a 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/transform/MultiDependencyTransform.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/transform/MultiDependencyTransform.java
@@ -41,11 +41,11 @@ public class MultiDependencyTransform extends StreamTransform {
      *         if pre streamNode is streamTransform, preNode is transformName
      */
     public MultiDependencyTransform(String transformName, TransformDefinition transformDefinition, String... preNodes) {
-        Preconditions.checkNotNull(transformDefinition, "transform definition cannot be null");
+        Preconditions.expectNotNull(transformDefinition, "transform definition cannot be null");
         this.transformDefinition = transformDefinition;
-        Preconditions.checkNotNull(transformName, "transform name cannot be empty");
+        Preconditions.expectNotNull(transformName, "transform name cannot be empty");
         this.transformName = transformName;
-        Preconditions.checkNotNullElements(preNodes, "pre nodes cannot be null");
+        Preconditions.expectNoNullElements(preNodes, "pre nodes cannot be null");
         for (String preNode : preNodes) {
             this.addPre(preNode);
         }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/transform/SingleDependencyTransform.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/transform/SingleDependencyTransform.java
index ac5e22e4a..83d5e4c17 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/transform/SingleDependencyTransform.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/transform/SingleDependencyTransform.java
@@ -39,11 +39,11 @@ public class SingleDependencyTransform extends StreamTransform {
      *         if pre streamNode is streamTransform, preNode is transformName
      */
     public SingleDependencyTransform(String transformName, TransformDefinition transformDefinition, String preNode) {
-        Preconditions.checkNotNull(transformDefinition, "transform definition cannot be null");
+        Preconditions.expectNotNull(transformDefinition, "transform definition cannot be null");
         this.transformDefinition = transformDefinition;
-        Preconditions.checkNotNull(transformName, "transform name cannot be null");
+        Preconditions.expectNotNull(transformName, "transform name cannot be null");
         this.transformName = transformName;
-        Preconditions.checkNotNull(preNode, "pre nodes cannot be null");
+        Preconditions.expectNotNull(preNode, "pre nodes cannot be null");
         this.addPre(preNode);
     }
 
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/ClientUtils.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/ClientUtils.java
index 4adfbf620..5da762cc8 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/ClientUtils.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/ClientUtils.java
@@ -68,8 +68,8 @@ public class ClientUtils {
         int port = configuration.getBindPort();
 
         Authentication authentication = configuration.getAuthentication();
-        Preconditions.checkNotNull(authentication, "inlong should be authenticated");
-        Preconditions.checkTrue(authentication instanceof DefaultAuthentication,
+        Preconditions.expectNotNull(authentication, "inlong should be authenticated");
+        Preconditions.expectTrue(authentication instanceof DefaultAuthentication,
                 "inlong only support default authentication");
         DefaultAuthentication defaultAuthentication = (DefaultAuthentication) authentication;
 
@@ -101,7 +101,7 @@ public class ClientUtils {
         String url = request.url().encodedPath();
         try {
             retrofit2.Response<T> response = call.execute();
-            Preconditions.checkTrue(response.isSuccessful(),
+            Preconditions.expectTrue(response.isSuccessful(),
                     String.format(REQUEST_FAILED_MSG, url, response.message()));
             return response.body();
         } catch (IOException e) {
@@ -116,6 +116,6 @@ public class ClientUtils {
      * @param response response
      */
     public static void assertRespSuccess(Response<?> response) {
-        Preconditions.checkTrue(response.isSuccess(), String.format(REQUEST_FAILED_MSG, response.getErrMsg(), null));
+        Preconditions.expectTrue(response.isSuccess(), String.format(REQUEST_FAILED_MSG, response.getErrMsg(), null));
     }
 }
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/InlongGroupTransfer.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/InlongGroupTransfer.java
index 286cd2b9c..4ea68d7fe 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/InlongGroupTransfer.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/InlongGroupTransfer.java
@@ -45,9 +45,9 @@ public class InlongGroupTransfer {
      * Create inlong group info from group config.
      */
     public static InlongGroupInfo createGroupInfo(InlongGroupInfo groupInfo, BaseSortConf sortConf) {
-        Preconditions.checkNotNull(groupInfo, "Inlong group info cannot be null");
+        Preconditions.expectNotNull(groupInfo, "Inlong group info cannot be null");
         String groupId = groupInfo.getInlongGroupId();
-        Preconditions.checkNotEmpty(groupId, "groupId cannot be empty");
+        Preconditions.expectNotEmpty(groupId, "groupId cannot be empty");
         // init extensions
         if (groupInfo.getExtList() == null) {
             groupInfo.setExtList(new ArrayList<>());
@@ -57,7 +57,7 @@ public class InlongGroupTransfer {
         if (groupInfo.getAuthentication() != null) {
             Authentication authentication = groupInfo.getAuthentication();
             AuthType authType = authentication.getAuthType();
-            Preconditions.checkTrue(authType == AuthType.TOKEN,
+            Preconditions.expectTrue(authType == AuthType.TOKEN,
                     String.format("Unsupported authentication %s for Pulsar", authType.name()));
             TokenAuthentication tokenAuthentication = (TokenAuthentication) authentication;
             InlongGroupExtInfo authTypeExt = new InlongGroupExtInfo();
@@ -106,7 +106,7 @@ public class InlongGroupTransfer {
         if (flinkSortConf.getAuthentication() != null) {
             Authentication authentication = flinkSortConf.getAuthentication();
             AuthType authType = authentication.getAuthType();
-            Preconditions.checkTrue(authType == AuthType.SECRET_AND_TOKEN,
+            Preconditions.expectTrue(authType == AuthType.SECRET_AND_TOKEN,
                     String.format("Unsupported authentication %s for Flink", authType.name()));
             final SecretTokenAuthentication secretTokenAuthentication = (SecretTokenAuthentication) authentication;
             InlongGroupExtInfo authTypeExt = new InlongGroupExtInfo();
diff --git a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/StreamTransformTransfer.java b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/StreamTransformTransfer.java
index ed57308da..2c01c00ce 100644
--- a/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/StreamTransformTransfer.java
+++ b/inlong-manager/manager-client/src/main/java/org/apache/inlong/manager/client/api/util/StreamTransformTransfer.java
@@ -45,11 +45,11 @@ public class StreamTransformTransfer {
     public static TransformRequest createTransformRequest(StreamTransform streamTransform,
             InlongStreamInfo streamInfo) {
         TransformRequest transformRequest = new TransformRequest();
-        Preconditions.checkNotEmpty(streamTransform.getTransformName(), "TransformName should not be null");
+        Preconditions.expectNotEmpty(streamTransform.getTransformName(), "TransformName should not be null");
         transformRequest.setTransformName(streamTransform.getTransformName());
         transformRequest.setInlongGroupId(streamInfo.getInlongGroupId());
         transformRequest.setInlongStreamId(streamInfo.getInlongStreamId());
-        Preconditions.checkNotNull(streamTransform.getTransformDefinition(), "TransformDefinition should not be null");
+        Preconditions.expectNotNull(streamTransform.getTransformDefinition(), "TransformDefinition should not be null");
         TransformDefinition transformDefinition = streamTransform.getTransformDefinition();
         transformRequest.setTransformType(transformDefinition.getTransformType().getType());
         transformRequest.setVersion(InlongConstants.INITIAL_VERSION);
diff --git a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/DefaultAuthentication.java b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/DefaultAuthentication.java
index 8185622cd..359588000 100644
--- a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/DefaultAuthentication.java
+++ b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/DefaultAuthentication.java
@@ -56,7 +56,7 @@ public class DefaultAuthentication implements Authentication {
 
     @Override
     public void configure(Map<String, String> properties) {
-        Preconditions.checkNotEmpty(properties, "Properties cannot be empty when init DefaultAuthentication");
+        Preconditions.expectNotEmpty(properties, "Properties cannot be empty when init DefaultAuthentication");
         this.username = properties.get(USERNAME);
         this.password = properties.get(PASSWORD);
     }
diff --git a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/SecretAuthentication.java b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/SecretAuthentication.java
index ec542701b..94cd4a015 100644
--- a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/SecretAuthentication.java
+++ b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/SecretAuthentication.java
@@ -57,7 +57,7 @@ public class SecretAuthentication implements Authentication {
 
     @Override
     public void configure(Map<String, String> properties) {
-        Preconditions.checkNotEmpty(properties, "Properties cannot be empty when init SecretAuthentication");
+        Preconditions.expectNotEmpty(properties, "Properties cannot be empty when init SecretAuthentication");
         this.secretId = properties.get(SECRET_ID);
         this.secretKey = properties.get(SECRET_KEY);
     }
diff --git a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/TokenAuthentication.java b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/TokenAuthentication.java
index 6caf26f6e..bdfe736f1 100644
--- a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/TokenAuthentication.java
+++ b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/auth/TokenAuthentication.java
@@ -49,7 +49,7 @@ public class TokenAuthentication implements Authentication {
 
     @Override
     public void configure(Map<String, String> properties) {
-        Preconditions.checkNotEmpty(properties, "Properties cannot be empty when init TokenAuthentication");
+        Preconditions.expectNotEmpty(properties, "Properties cannot be empty when init TokenAuthentication");
         this.token = properties.get(TOKEN);
     }
 
diff --git a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/enums/FieldType.java b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/enums/FieldType.java
index eb0d335be..a6fcfb767 100644
--- a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/enums/FieldType.java
+++ b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/enums/FieldType.java
@@ -56,7 +56,7 @@ public enum FieldType {
     KEYWORD;
 
     public static FieldType forName(String name) {
-        Preconditions.checkNotNull(name, "FieldType should not be null");
+        Preconditions.expectNotNull(name, "FieldType should not be null");
         for (FieldType value : values()) {
             if (value.toString().equalsIgnoreCase(name)) {
                 return value;
diff --git a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/HttpUtils.java b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/HttpUtils.java
index 09c72464a..ace3d513f 100644
--- a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/HttpUtils.java
+++ b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/HttpUtils.java
@@ -108,7 +108,7 @@ public class HttpUtils {
         ResponseEntity<T> response = restTemplate.exchange(url, httpMethod, requestEntity, typeReference);
 
         log.debug("success request to {}, status code {}", url, response.getStatusCode());
-        Preconditions.checkTrue(response.getStatusCode().is2xxSuccessful(), "Request failed");
+        Preconditions.expectTrue(response.getStatusCode().is2xxSuccessful(), "Request failed");
         return response.getBody();
     }
 
diff --git a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/InlongCollectionUtils.java b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/InlongCollectionUtils.java
index 79d434ab8..3bf3d24c3 100644
--- a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/InlongCollectionUtils.java
+++ b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/InlongCollectionUtils.java
@@ -45,8 +45,8 @@ public class InlongCollectionUtils {
         if (CollectionUtils.isEmpty(originCollection)) {
             return ImmutableMap.of();
         }
-        Preconditions.checkNotNull(keyTransformFunction, "KeyTransformFunction cannot be null");
-        Preconditions.checkNotNull(valueTransformFunction, "ValueTransformFunction cannot be null");
+        Preconditions.expectNotNull(keyTransformFunction, "KeyTransformFunction cannot be null");
+        Preconditions.expectNotNull(valueTransformFunction, "ValueTransformFunction cannot be null");
 
         ImmutableMap.Builder<K, V> builder = ImmutableMap.builder();
         originCollection.forEach(originObject -> builder.put(keyTransformFunction.apply(originObject),
diff --git a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/Preconditions.java b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/Preconditions.java
index 4def9ead8..b0326b18c 100644
--- a/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/Preconditions.java
+++ b/inlong-manager/manager-common/src/main/java/org/apache/inlong/manager/common/util/Preconditions.java
@@ -34,71 +34,71 @@ import java.util.function.Supplier;
  */
 public class Preconditions {
 
-    public static void checkNotNull(Object obj, String errMsg) {
-        checkTrue(obj != null, errMsg);
+    public static void expectNotNull(Object obj, String errMsg) {
+        expectTrue(obj != null, errMsg);
     }
 
-    public static void checkNotNull(Object obj, Supplier<String> errMsg) {
-        checkTrue(obj != null, errMsg);
+    public static void expectNotNull(Object obj, Supplier<String> errMsg) {
+        expectTrue(obj != null, errMsg);
     }
 
-    public static void checkNull(Object obj, String errMsg) {
-        checkTrue(obj == null, errMsg);
+    public static void expectNull(Object obj, String errMsg) {
+        expectTrue(obj == null, errMsg);
     }
 
-    public static void checkNull(Object obj, Supplier<String> errMsg) {
-        checkTrue(obj == null, errMsg);
+    public static void expectNull(Object obj, Supplier<String> errMsg) {
+        expectTrue(obj == null, errMsg);
     }
 
-    public static void checkEmpty(String str, String errMsg) {
-        checkTrue(str == null || str.isEmpty(), errMsg);
+    public static void expectEmpty(String str, String errMsg) {
+        expectTrue(str == null || str.isEmpty(), errMsg);
     }
 
-    public static void checkEmpty(String str, Supplier<String> errMsg) {
-        checkTrue(str == null || str.isEmpty(), errMsg);
+    public static void expectEmpty(String str, Supplier<String> errMsg) {
+        expectTrue(str == null || str.isEmpty(), errMsg);
     }
 
-    public static void checkEmpty(Collection<?> str, String errMsg) {
-        checkTrue(str == null || str.isEmpty(), errMsg);
+    public static void expectEmpty(Collection<?> str, String errMsg) {
+        expectTrue(str == null || str.isEmpty(), errMsg);
     }
 
-    public static void checkEmpty(Collection<?> collection, Supplier<String> errMsg) {
-        checkTrue(collection == null || collection.isEmpty(), errMsg);
+    public static void expectEmpty(Collection<?> collection, Supplier<String> errMsg) {
+        expectTrue(collection == null || collection.isEmpty(), errMsg);
     }
 
-    public static void checkEmpty(Map<?, ?> map, String errMsg) {
-        checkTrue(map == null || map.isEmpty(), errMsg);
+    public static void expectEmpty(Map<?, ?> map, String errMsg) {
+        expectTrue(map == null || map.isEmpty(), errMsg);
     }
 
-    public static void checkEmpty(Map<?, ?> map, Supplier<String> errMsg) {
-        checkTrue(map == null || map.isEmpty(), errMsg);
+    public static void expectEmpty(Map<?, ?> map, Supplier<String> errMsg) {
+        expectTrue(map == null || map.isEmpty(), errMsg);
     }
 
-    public static void checkNotEmpty(String str, String errMsg) {
-        checkTrue(str != null && !str.isEmpty(), errMsg);
+    public static void expectNotEmpty(String str, String errMsg) {
+        expectTrue(str != null && !str.isEmpty(), errMsg);
     }
 
-    public static void checkNotEmpty(String str, Supplier<String> errMsg) {
-        checkTrue(str != null && !str.isEmpty(), errMsg);
+    public static void expectNotEmpty(String str, Supplier<String> errMsg) {
+        expectTrue(str != null && !str.isEmpty(), errMsg);
     }
 
-    public static void checkNotEmpty(Collection<?> collection, String errMsg) {
-        checkTrue(collection != null && !collection.isEmpty(), errMsg);
+    public static void expectNotEmpty(Collection<?> collection, String errMsg) {
+        expectTrue(collection != null && !collection.isEmpty(), errMsg);
     }
 
-    public static void checkNotEmpty(Collection<?> collection, Supplier<String> errMsg) {
-        checkTrue(collection != null && !collection.isEmpty(), errMsg);
+    public static void expectNotEmpty(Collection<?> collection, Supplier<String> errMsg) {
+        expectTrue(collection != null && !collection.isEmpty(), errMsg);
     }
 
-    public static void checkNotEmpty(Map<?, ?> map, String errMsg) {
-        checkTrue(map != null && !map.isEmpty(), errMsg);
+    public static void expectNotEmpty(Map<?, ?> map, String errMsg) {
+        expectTrue(map != null && !map.isEmpty(), errMsg);
     }
 
-    public static void checkNotEmpty(Map<?, ?> map, Supplier<String> errMsg) {
-        checkTrue(map != null && !map.isEmpty(), errMsg);
+    public static void expectNotEmpty(Map<?, ?> map, Supplier<String> errMsg) {
+        expectTrue(map != null && !map.isEmpty(), errMsg);
     }
 
-    public static void checkNotNullElements(Object[] array, String errMsg) {
+    public static void expectNoNullElements(Object[] array, String errMsg) {
         if (array != null) {
             for (Object o : array) {
                 if (o == null) {
@@ -108,57 +108,57 @@ public class Preconditions {
         }
     }
 
-    public static void checkFalse(boolean condition, String errMsg) {
-        checkTrue(!condition, errMsg);
+    public static void expectFalse(boolean condition, String errMsg) {
+        expectTrue(!condition, errMsg);
     }
 
-    public static void checkFalse(boolean condition, Supplier<String> errMsg) {
-        checkTrue(!condition, errMsg);
+    public static void expectFalse(boolean condition, Supplier<String> errMsg) {
+        expectTrue(!condition, errMsg);
     }
 
-    public static void checkTrue(boolean condition, Supplier<String> errMsg) {
+    public static void expectTrue(boolean condition, Supplier<String> errMsg) {
         if (!condition) {
             throw new IllegalArgumentException(errMsg.get());
         }
     }
 
-    public static void checkTrue(boolean condition, String errMsg) {
+    public static void expectTrue(boolean condition, String errMsg) {
         if (!condition) {
             throw new IllegalArgumentException(errMsg);
         }
     }
 
-    public static void checkBlank(String obj, ErrorCodeEnum errorCodeEnum) {
+    public static void expectNotBlank(String obj, ErrorCodeEnum errorCodeEnum) {
         if (StringUtils.isBlank(obj)) {
             throw new BusinessException(errorCodeEnum);
         }
     }
 
-    public static void checkBlank(String obj, ErrorCodeEnum errorCodeEnum, String errMsg) {
+    public static void expectNotBlank(String obj, ErrorCodeEnum errorCodeEnum, String errMsg) {
         if (StringUtils.isBlank(obj)) {
             throw new BusinessException(errorCodeEnum, errMsg);
         }
     }
 
-    public static void checkNull(Object obj, ErrorCodeEnum errorCodeEnum) {
+    public static void expectNotNull(Object obj, ErrorCodeEnum errorCodeEnum) {
         if (obj == null) {
             throw new BusinessException(errorCodeEnum);
         }
     }
 
-    public static void checkNull(Object obj, ErrorCodeEnum errorCodeEnum, String errMsg) {
+    public static void expectNotNull(Object obj, ErrorCodeEnum errorCodeEnum, String errMsg) {
         if (obj == null) {
             throw new BusinessException(errorCodeEnum, errMsg);
         }
     }
 
-    public static void chkNotEquals(Object a, Object b, ErrorCodeEnum errorCodeEnum) {
+    public static void expectEquals(Object a, Object b, ErrorCodeEnum errorCodeEnum) {
         if (!Objects.equals(a, b)) {
             throw new BusinessException(errorCodeEnum);
         }
     }
 
-    public static void chkNotEquals(Object a, Object b, ErrorCodeEnum errorCodeEnum, String errMsg) {
+    public static void expectEquals(Object a, Object b, ErrorCodeEnum errorCodeEnum, String errMsg) {
         if (!Objects.equals(a, b)) {
             throw new BusinessException(errorCodeEnum, errMsg);
         }
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sink/hudi/HudiPartition.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sink/hudi/HudiPartition.java
index cec8e0f48..66c1f90ab 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sink/hudi/HudiPartition.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sink/hudi/HudiPartition.java
@@ -38,7 +38,7 @@ public enum HudiPartition {
      * Get partition type from name
      */
     public static HudiPartition forName(String name) {
-        Preconditions.checkNotNull(name, "HudiPartition should not be null");
+        Preconditions.expectNotNull(name, "HudiPartition should not be null");
         for (HudiPartition value : values()) {
             if (value.toString().equalsIgnoreCase(name)) {
                 return value;
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sink/iceberg/IcebergPartition.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sink/iceberg/IcebergPartition.java
index 9f438c5b1..9207f65d4 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sink/iceberg/IcebergPartition.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sink/iceberg/IcebergPartition.java
@@ -38,7 +38,7 @@ public enum IcebergPartition {
      * Get partition type from name
      */
     public static IcebergPartition forName(String name) {
-        Preconditions.checkNotNull(name, "IcebergPartition should not be null");
+        Preconditions.expectNotNull(name, "IcebergPartition should not be null");
         for (IcebergPartition value : values()) {
             if (value.toString().equalsIgnoreCase(name)) {
                 return value;
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/FieldRelationUtils.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/FieldRelationUtils.java
index 57913443a..ed8621329 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/FieldRelationUtils.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/FieldRelationUtils.java
@@ -155,7 +155,7 @@ public class FieldRelationUtils {
             List<StreamField> fieldList, String transformName,
             SplitterDefinition splitterDefinition, String preNodes,
             Map<String, StreamField> constantFieldMap) {
-        Preconditions.checkNotEmpty(preNodes, "PreNodes of splitter should not be null");
+        Preconditions.expectNotEmpty(preNodes, "PreNodes of splitter should not be null");
         String preNode = preNodes.split(",")[0];
         List<SplitRule> splitRules = splitterDefinition.getSplitRules();
         Set<String> splitFields = Sets.newHashSet();
@@ -177,7 +177,7 @@ public class FieldRelationUtils {
      */
     private static List<FieldRelation> createReplacerFieldRelations(List<StreamField> fieldList, String transformName,
             StringReplacerDefinition replacerDefinition, String preNodes, Map<String, StreamField> constantFieldMap) {
-        Preconditions.checkNotEmpty(preNodes, "PreNodes of splitter should not be null");
+        Preconditions.expectNotEmpty(preNodes, "PreNodes of splitter should not be null");
         String preNode = preNodes.split(",")[0];
         List<ReplaceRule> replaceRules = replacerDefinition.getReplaceRules();
         Set<String> replaceFields = Sets.newHashSet();
@@ -197,7 +197,7 @@ public class FieldRelationUtils {
      */
     private static List<FieldRelation> createEncryptFieldRelations(List<StreamField> fieldList, String transformName,
             EncryptDefinition encryptDefinition, String preNodes, Map<String, StreamField> constantFieldMap) {
-        Preconditions.checkNotEmpty(preNodes, "PreNodes of encrypt should not be null");
+        Preconditions.expectNotEmpty(preNodes, "PreNodes of encrypt should not be null");
         String preNode = preNodes.split(",")[0];
         List<EncryptRule> encryptRules = encryptDefinition.getEncryptRules();
         Set<String> encryptFields = Sets.newHashSet();
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/FilterFunctionUtils.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/FilterFunctionUtils.java
index 2609bfd7d..be28d26ed 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/FilterFunctionUtils.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/FilterFunctionUtils.java
@@ -85,7 +85,7 @@ public class FilterFunctionUtils {
      */
     public static List<FilterFunction> createFilterFunctions(FilterDefinition filterDefinition, String transformName) {
         FilterMode filterMode = filterDefinition.getFilterMode();
-        Preconditions.checkFalse(filterMode == FilterMode.SCRIPT,
+        Preconditions.expectFalse(filterMode == FilterMode.SCRIPT,
                 String.format("Unsupported filterMode=%s for inlong", filterMode));
         List<FilterRule> filterRules = filterDefinition.getFilterRules();
         List<FilterFunction> filterFunctions = filterRules.stream()
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/StreamParseUtils.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/StreamParseUtils.java
index 309646fda..8a6d5da51 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/StreamParseUtils.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/sort/util/StreamParseUtils.java
@@ -110,7 +110,7 @@ public class StreamParseUtils {
     }
 
     public static StreamPipeline parseStreamPipeline(String tempView, String inlongStreamId) {
-        Preconditions.checkNotEmpty(tempView,
+        Preconditions.expectNotEmpty(tempView,
                 String.format(" should not be null for streamId=%s", inlongStreamId));
         return GSON.fromJson(tempView, StreamPipeline.class);
     }
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamNode.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamNode.java
index f29cf3a0c..ba6838cbd 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamNode.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamNode.java
@@ -43,7 +43,7 @@ public class StreamNode {
     protected List<StreamField> fieldList;
 
     public void addPre(String pre) {
-        Preconditions.checkNotEmpty(pre, "Pre node should not be empty");
+        Preconditions.expectNotEmpty(pre, "Pre node should not be empty");
         if (preNodes == null) {
             preNodes = Sets.newHashSet();
         }
@@ -51,7 +51,7 @@ public class StreamNode {
     }
 
     public void addPost(String post) {
-        Preconditions.checkNotEmpty(post, "Post node should not be empty");
+        Preconditions.expectNotEmpty(post, "Post node should not be empty");
         if (postNodes == null) {
             postNodes = Sets.newHashSet();
         }
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamNodeRelation.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamNodeRelation.java
index 4eaefe7ec..95991dc53 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamNodeRelation.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamNodeRelation.java
@@ -43,12 +43,12 @@ public class StreamNodeRelation {
     }
 
     public void addInputNode(String inputNode) {
-        Preconditions.checkNotEmpty(inputNode, "Input node should not be empty");
+        Preconditions.expectNotEmpty(inputNode, "Input node should not be empty");
         inputNodes.add(inputNode);
     }
 
     public void addOutputNode(String outputNode) {
-        Preconditions.checkNotEmpty(outputNode, "Input node should not be empty");
+        Preconditions.expectNotEmpty(outputNode, "Input node should not be empty");
         outputNodes.add(outputNode);
     }
 }
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamPipeline.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamPipeline.java
index 563450871..0682b8c25 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamPipeline.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/stream/StreamPipeline.java
@@ -45,7 +45,7 @@ public class StreamPipeline {
     }
 
     public StreamPipeline(List<StreamNodeRelation> pipeline) {
-        Preconditions.checkNotNull(pipeline, "Pipeline should not be null");
+        Preconditions.expectNotNull(pipeline, "Pipeline should not be null");
         this.pipeline = pipeline;
     }
 
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/ApplyConsumeProcessForm.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/ApplyConsumeProcessForm.java
index 9e535c989..9f6e0d0b5 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/ApplyConsumeProcessForm.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/ApplyConsumeProcessForm.java
@@ -41,7 +41,7 @@ public class ApplyConsumeProcessForm extends BaseProcessForm {
 
     @Override
     public void validate() throws FormValidateException {
-        Preconditions.checkNotNull(consumeInfo, "Inlong consume cannot be empty");
+        Preconditions.expectNotNull(consumeInfo, "Inlong consume cannot be empty");
     }
 
     @Override
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/ApplyGroupProcessForm.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/ApplyGroupProcessForm.java
index 985d1e950..43ad2d457 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/ApplyGroupProcessForm.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/ApplyGroupProcessForm.java
@@ -46,7 +46,7 @@ public class ApplyGroupProcessForm extends BaseProcessForm {
 
     @Override
     public void validate() throws FormValidateException {
-        Preconditions.checkNotNull(groupInfo, "inlong group info is empty");
+        Preconditions.expectNotNull(groupInfo, "inlong group info is empty");
     }
 
     @Override
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/GroupResourceProcessForm.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/GroupResourceProcessForm.java
index d1895c416..e3ac83476 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/GroupResourceProcessForm.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/process/GroupResourceProcessForm.java
@@ -46,7 +46,7 @@ public class GroupResourceProcessForm extends BaseProcessForm {
 
     @Override
     public void validate() throws FormValidateException {
-        Preconditions.checkNotNull(groupInfo, "InlongGroupInfo cannot be null");
+        Preconditions.expectNotNull(groupInfo, "InlongGroupInfo cannot be null");
     }
 
     @Override
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/task/ConsumeApproveForm.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/task/ConsumeApproveForm.java
index ef2c0c952..2b12b950c 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/task/ConsumeApproveForm.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/task/ConsumeApproveForm.java
@@ -37,7 +37,7 @@ public class ConsumeApproveForm extends BaseTaskForm {
 
     @Override
     public void validate() throws FormValidateException {
-        Preconditions.checkNotEmpty(consumerGroup, "Consumer group cannot be empty");
+        Preconditions.expectNotEmpty(consumerGroup, "Consumer group cannot be empty");
     }
 
     @Override
diff --git a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/task/InlongGroupApproveForm.java b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/task/InlongGroupApproveForm.java
index eeb5e2641..76c784a79 100644
--- a/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/task/InlongGroupApproveForm.java
+++ b/inlong-manager/manager-pojo/src/main/java/org/apache/inlong/manager/pojo/workflow/form/task/InlongGroupApproveForm.java
@@ -44,7 +44,7 @@ public class InlongGroupApproveForm extends BaseTaskForm {
 
     @Override
     public void validate() throws FormValidateException {
-        Preconditions.checkNotNull(groupApproveInfo, "inlong group approve info is empty");
+        Preconditions.expectNotNull(groupApproveInfo, "inlong group approve info is empty");
     }
 
     @Override
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/InlongClusterServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/InlongClusterServiceImpl.java
index 23054dd1d..08fa4ee5c 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/InlongClusterServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/InlongClusterServiceImpl.java
@@ -122,8 +122,8 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     @Override
     public Integer saveTag(ClusterTagRequest request, String operator) {
         LOGGER.debug("begin to save cluster tag {}", request);
-        Preconditions.checkNotNull(request, "inlong cluster request cannot be empty");
-        Preconditions.checkNotNull(request.getClusterTag(), "cluster tag cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster request cannot be empty");
+        Preconditions.expectNotNull(request.getClusterTag(), "cluster tag cannot be empty");
 
         // check if the cluster tag already exist
         String clusterTag = request.getClusterTag();
@@ -164,7 +164,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
     @Override
     public ClusterTagResponse getTag(Integer id, String currentUser) {
-        Preconditions.checkNotNull(id, "inlong cluster tag id cannot be empty");
+        Preconditions.expectNotNull(id, "inlong cluster tag id cannot be empty");
         InlongClusterTagEntity entity = clusterTagMapper.selectById(id);
         if (entity == null) {
             LOGGER.error("inlong cluster tag not found by id={}", id);
@@ -172,7 +172,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
         }
         UserEntity userEntity = userMapper.selectByName(currentUser);
         boolean isInCharge = Preconditions.inSeparatedString(currentUser, entity.getInCharges(), InlongConstants.COMMA);
-        Preconditions.checkTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
+        Preconditions.expectTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
                 "Current user does not have permission to get cluster tag");
 
         ClusterTagResponse response = CommonBeanUtils.copyProperties(entity, ClusterTagResponse::new);
@@ -235,9 +235,9 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     @Transactional(rollbackFor = Throwable.class, isolation = Isolation.REPEATABLE_READ)
     public Boolean updateTag(ClusterTagRequest request, String operator) {
         LOGGER.debug("begin to update cluster tag={}", request);
-        Preconditions.checkNotNull(request, "inlong cluster request cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster request cannot be empty");
         Integer id = request.getId();
-        Preconditions.checkNotNull(id, "cluster tag id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster tag id cannot be empty");
         InlongClusterTagEntity exist = clusterTagMapper.selectById(id);
         if (exist == null) {
             LOGGER.warn("inlong cluster tag was not exist for id={}", id);
@@ -257,7 +257,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
         UserEntity userEntity = userMapper.selectByName(operator);
         boolean isInCharge = Preconditions.inSeparatedString(operator, exist.getInCharges(), InlongConstants.COMMA);
-        Preconditions.checkTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
+        Preconditions.expectTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
                 "Current user does not have permission to update cluster tag");
 
         // if the cluster tag was changed, need to check whether the new tag already exists
@@ -319,7 +319,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
             }
         }
         // check record version
-        Preconditions.chkNotEquals(exist.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(exist.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         exist.getVersion(), request.getVersion()));
@@ -368,7 +368,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
     @Override
     public Boolean deleteTag(Integer id, String operator) {
-        Preconditions.checkNotNull(id, "cluster tag id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster tag id cannot be empty");
         InlongClusterTagEntity exist = clusterTagMapper.selectById(id);
         if (exist == null || exist.getIsDeleted() > InlongConstants.UN_DELETED) {
             LOGGER.error("inlong cluster tag not found by id={}", id);
@@ -376,7 +376,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
         }
         UserEntity userEntity = userMapper.selectByName(operator);
         boolean isInCharge = Preconditions.inSeparatedString(operator, exist.getInCharges(), InlongConstants.COMMA);
-        Preconditions.checkTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
+        Preconditions.expectTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
                 "Current user does not have permission to delete cluster tag");
 
         // check if there are some InlongGroups that uses this tag
@@ -444,7 +444,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     @Override
     public Integer save(ClusterRequest request, String operator) {
         LOGGER.debug("begin to save inlong cluster={}", request);
-        Preconditions.checkNotNull(request, "inlong cluster request cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster request cannot be empty");
 
         // check if the cluster already exist
         String clusterTag = request.getClusterTags();
@@ -485,7 +485,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
     @Override
     public ClusterInfo get(Integer id, String currentUser) {
-        Preconditions.checkNotNull(id, "inlong cluster id cannot be empty");
+        Preconditions.expectNotNull(id, "inlong cluster id cannot be empty");
         InlongClusterEntity entity = clusterMapper.selectById(id);
         if (entity == null) {
             LOGGER.error("inlong cluster not found by id={}", id);
@@ -597,7 +597,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     @Override
     public Boolean update(ClusterRequest request, String operator) {
         LOGGER.debug("begin to update inlong cluster: {}", request);
-        Preconditions.checkNotNull(request, "inlong cluster info cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster info cannot be empty");
         Integer id = request.getId();
         InlongClusterEntity entity = clusterMapper.selectById(id);
         if (entity == null) {
@@ -658,7 +658,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     @Override
     public UpdateResult updateByKey(ClusterRequest request, String operator) {
         LOGGER.debug("begin to update inlong cluster: {}", request);
-        Preconditions.checkNotNull(request, "inlong cluster info cannot be null");
+        Preconditions.expectNotNull(request, "inlong cluster info cannot be null");
         String name = request.getName();
         String type = request.getType();
         InlongClusterEntity entity = clusterMapper.selectByNameAndType(name, type);
@@ -682,13 +682,13 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     @Override
     public Boolean bindTag(BindTagRequest request, String operator) {
         LOGGER.info("begin to bind or unbind cluster tag: {}", request);
-        Preconditions.checkNotNull(request, "inlong cluster info cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster info cannot be empty");
         String clusterTag = request.getClusterTag();
-        Preconditions.checkNotNull(clusterTag, "cluster tag cannot be empty");
+        Preconditions.expectNotNull(clusterTag, "cluster tag cannot be empty");
         InlongClusterTagEntity exist = clusterTagMapper.selectByTag(clusterTag);
         UserEntity userEntity = userMapper.selectByName(operator);
         boolean isInCharge = Preconditions.inSeparatedString(operator, exist.getInCharges(), InlongConstants.COMMA);
-        Preconditions.checkTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
+        Preconditions.expectTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
                 "Current user does not have permission to bind or unbind cluster tag");
         if (CollectionUtils.isNotEmpty(request.getBindClusters())) {
             request.getBindClusters().forEach(id -> {
@@ -764,8 +764,8 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
     @Override
     public Boolean deleteByKey(String name, String type, String operator) {
-        Preconditions.checkNotNull(name, "cluster name should not be empty or null");
-        Preconditions.checkNotNull(name, "cluster type should not be empty or null");
+        Preconditions.expectNotNull(name, "cluster name should not be empty or null");
+        Preconditions.expectNotNull(name, "cluster type should not be empty or null");
         InlongClusterEntity entity = clusterMapper.selectByNameAndType(name, type);
         if (entity == null || entity.getIsDeleted() > InlongConstants.UN_DELETED) {
             LOGGER.error("inlong cluster not found by clusterName={}, type={} or was already deleted",
@@ -774,7 +774,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
         }
         UserEntity userEntity = userMapper.selectByName(operator);
         boolean isInCharge = Preconditions.inSeparatedString(operator, entity.getInCharges(), InlongConstants.COMMA);
-        Preconditions.checkTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
+        Preconditions.expectTrue(isInCharge || userEntity.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
                 "Current user does not have permission to delete cluster info");
 
         List<InlongClusterNodeEntity> nodeEntities = clusterNodeMapper.selectByParentId(entity.getId(), null);
@@ -798,7 +798,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
     @Override
     public Boolean delete(Integer id, String operator) {
-        Preconditions.checkNotNull(id, "cluster id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster id cannot be empty");
         InlongClusterEntity entity = clusterMapper.selectById(id);
         if (entity == null || entity.getIsDeleted() > InlongConstants.UN_DELETED) {
             LOGGER.error("inlong cluster not found by id={}, or was already deleted", id);
@@ -858,7 +858,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     @Override
     public Integer saveNode(ClusterNodeRequest request, String operator) {
         LOGGER.debug("begin to insert inlong cluster node={}", request);
-        Preconditions.checkNotNull(request, "cluster node info cannot be empty");
+        Preconditions.expectNotNull(request, "cluster node info cannot be empty");
 
         // check cluster node if exist
         InlongClusterNodeEntity exist = clusterNodeMapper.selectByUniqueKey(request);
@@ -902,7 +902,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
     @Override
     public ClusterNodeResponse getNode(Integer id, String currentUser) {
-        Preconditions.checkNotNull(id, "cluster node id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster node id cannot be empty");
         InlongClusterNodeEntity entity = clusterNodeMapper.selectById(id);
         if (entity == null) {
             LOGGER.error("inlong cluster node not found by id={}", id);
@@ -941,7 +941,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
             return new PageResult<>(nodeList, (long) nodeList.size());
         }
         Integer parentId = request.getParentId();
-        Preconditions.checkNotNull(parentId, "Cluster id cannot be empty");
+        Preconditions.expectNotNull(parentId, "Cluster id cannot be empty");
         InlongClusterEntity cluster = clusterMapper.selectById(parentId);
         String message = "Current user does not have permission to get cluster node list";
         checkUser(cluster, currentUser, message);
@@ -1062,7 +1062,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
     @Override
     public List<String> listNodeIpByType(String type) {
-        Preconditions.checkNotNull(type, "cluster type cannot be empty");
+        Preconditions.expectNotNull(type, "cluster type cannot be empty");
         ClusterPageRequest request = new ClusterPageRequest();
         request.setType(type);
         List<InlongClusterNodeEntity> nodeList = clusterNodeMapper.selectByCondition(request);
@@ -1082,7 +1082,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     @Transactional(rollbackFor = Throwable.class, isolation = Isolation.REPEATABLE_READ)
     public Boolean updateNode(ClusterNodeRequest request, String operator) {
         LOGGER.debug("begin to update inlong cluster node={}", request);
-        Preconditions.checkNotNull(request, "inlong cluster node cannot be empty");
+        Preconditions.expectNotNull(request, "inlong cluster node cannot be empty");
         Integer id = request.getId();
         InlongClusterNodeEntity entity = clusterNodeMapper.selectById(id);
         if (entity == null) {
@@ -1090,10 +1090,10 @@ public class InlongClusterServiceImpl implements InlongClusterService {
             throw new BusinessException(ErrorCodeEnum.CLUSTER_NOT_FOUND);
         }
         // check type
-        Preconditions.chkNotEquals(entity.getType(), request.getType(),
+        Preconditions.expectEquals(entity.getType(), request.getType(),
                 ErrorCodeEnum.INVALID_PARAMETER, "type not allowed modify");
         // check record version
-        Preconditions.chkNotEquals(entity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(entity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         entity.getVersion(), request.getVersion()));
@@ -1127,10 +1127,10 @@ public class InlongClusterServiceImpl implements InlongClusterService {
                     String.format("cluster node not found by id=%s", request.getId()));
         }
         // check type
-        Preconditions.chkNotEquals(entity.getType(), request.getType(),
+        Preconditions.expectEquals(entity.getType(), request.getType(),
                 ErrorCodeEnum.INVALID_PARAMETER, "type not allowed modify");
         // check record version
-        Preconditions.chkNotEquals(entity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(entity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         entity.getVersion(), request.getVersion()));
@@ -1167,7 +1167,7 @@ public class InlongClusterServiceImpl implements InlongClusterService {
 
     @Override
     public Boolean deleteNode(Integer id, String operator) {
-        Preconditions.checkNotNull(id, "cluster node id cannot be empty");
+        Preconditions.expectNotNull(id, "cluster node id cannot be empty");
         InlongClusterNodeEntity entity = clusterNodeMapper.selectById(id);
         if (entity == null || entity.getIsDeleted() > InlongConstants.UN_DELETED) {
             LOGGER.error("inlong cluster node not found by id={}", id);
@@ -1473,16 +1473,16 @@ public class InlongClusterServiceImpl implements InlongClusterService {
     private void checkUser(InlongClusterEntity cluster, String user, String errMsg) {
         UserEntity userEntity = userMapper.selectByName(user);
         boolean isInCharge = Preconditions.inSeparatedString(user, cluster.getInCharges(), InlongConstants.COMMA);
-        Preconditions.checkTrue(isInCharge || UserTypeEnum.ADMIN.getCode().equals(userEntity.getAccountType()),
+        Preconditions.expectTrue(isInCharge || UserTypeEnum.ADMIN.getCode().equals(userEntity.getAccountType()),
                 errMsg);
     }
 
     private void chkUnmodifiableParams(InlongClusterEntity entity, ClusterRequest request) {
         // check type
-        Preconditions.chkNotEquals(entity.getType(), request.getType(),
+        Preconditions.expectEquals(entity.getType(), request.getType(),
                 ErrorCodeEnum.INVALID_PARAMETER, "type not allowed modify");
         // check record version
-        Preconditions.chkNotEquals(entity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(entity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         entity.getVersion(), request.getVersion()));
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/KafkaClusterOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/KafkaClusterOperator.java
index 589fca54d..d417c4a64 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/KafkaClusterOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/KafkaClusterOperator.java
@@ -95,7 +95,7 @@ public class KafkaClusterOperator extends AbstractClusterOperator {
     @Override
     public Boolean testConnection(ClusterRequest request) {
         String bootstrapServers = request.getUrl();
-        Preconditions.checkNotNull(bootstrapServers, "connection url cannot be empty");
+        Preconditions.expectNotNull(bootstrapServers, "connection url cannot be empty");
         Properties props = new Properties();
         props.put(AdminClientConfig.BOOTSTRAP_SERVERS_CONFIG, bootstrapServers);
         try (Admin ignored = Admin.create(props)) {
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/TubeClusterOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/TubeClusterOperator.java
index fcb6286e5..1a7d901ba 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/TubeClusterOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/cluster/TubeClusterOperator.java
@@ -99,7 +99,7 @@ public class TubeClusterOperator extends AbstractClusterOperator {
         int portBeginIndex = masterUrl.lastIndexOf(InlongConstants.COLON);
         String host = masterUrl.substring(hostBeginIndex + 1, portBeginIndex);
         int port = Integer.parseInt(masterUrl.substring(portBeginIndex + 1));
-        Preconditions.checkNotNull(masterUrl, "connection url cannot be empty");
+        Preconditions.expectNotNull(masterUrl, "connection url cannot be empty");
         boolean result;
         try {
             result = HttpUtils.checkConnectivity(host, port, 10, TimeUnit.SECONDS);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumeKafkaOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumeKafkaOperator.java
index 9922a6db7..e53f73d8f 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumeKafkaOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumeKafkaOperator.java
@@ -60,17 +60,17 @@ public class ConsumeKafkaOperator extends AbstractConsumeOperator {
     public void checkTopicInfo(InlongConsumeRequest request) {
         String groupId = request.getInlongGroupId();
         InlongGroupTopicInfo topicInfo = groupService.getTopic(groupId);
-        Preconditions.checkNotNull(topicInfo, "inlong group not exist: " + groupId);
+        Preconditions.expectNotNull(topicInfo, "inlong group not exist: " + groupId);
 
         InlongKafkaTopicInfo kafkaInfo = (InlongKafkaTopicInfo) topicInfo;
         String originTopic = request.getTopic();
-        Preconditions.checkTrue(kafkaInfo.getTopics().contains(originTopic),
+        Preconditions.expectTrue(kafkaInfo.getTopics().contains(originTopic),
                 "Kafka topic not exist for " + originTopic);
     }
 
     @Override
     public InlongConsumeInfo getFromEntity(InlongConsumeEntity entity) {
-        Preconditions.checkNotNull(entity, ErrorCodeEnum.CONSUME_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(entity, ErrorCodeEnum.CONSUME_NOT_FOUND.getMessage());
 
         ConsumeKafkaInfo kafkaInfo = new ConsumeKafkaInfo();
         CommonBeanUtils.copyProperties(entity, kafkaInfo);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumePulsarOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumePulsarOperator.java
index cf1f20d61..fe78788df 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumePulsarOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumePulsarOperator.java
@@ -87,7 +87,7 @@ public class ConsumePulsarOperator extends AbstractConsumeOperator {
         // one inlong group may have multiple Pulsar topics.
         String groupId = request.getInlongGroupId();
         InlongGroupTopicInfo topicInfo = groupService.getTopic(groupId);
-        Preconditions.checkNotNull(topicInfo, "inlong group not exist for groupId=" + groupId);
+        Preconditions.expectNotNull(topicInfo, "inlong group not exist for groupId=" + groupId);
 
         // check the origin topic from request exists
         InlongPulsarTopicInfo pulsarTopic = (InlongPulsarTopicInfo) topicInfo;
@@ -96,13 +96,13 @@ public class ConsumePulsarOperator extends AbstractConsumeOperator {
             originTopic = originTopic.substring(originTopic.lastIndexOf(InlongConstants.SLASH) + 1);
             request.setTopic(originTopic);
         }
-        Preconditions.checkTrue(pulsarTopic.getTopics().contains(originTopic),
+        Preconditions.expectTrue(pulsarTopic.getTopics().contains(originTopic),
                 "Pulsar topic not exist for " + originTopic);
     }
 
     @Override
     public InlongConsumeInfo getFromEntity(InlongConsumeEntity entity) {
-        Preconditions.checkNotNull(entity, ErrorCodeEnum.CONSUME_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(entity, ErrorCodeEnum.CONSUME_NOT_FOUND.getMessage());
 
         ConsumePulsarInfo consumeInfo = new ConsumePulsarInfo();
         CommonBeanUtils.copyProperties(entity, consumeInfo);
@@ -114,7 +114,7 @@ public class ConsumePulsarOperator extends AbstractConsumeOperator {
         InlongGroupInfo groupInfo = groupService.get(groupId);
         String clusterTag = groupInfo.getInlongClusterTag();
         List<ClusterInfo> clusterInfos = clusterService.listByTagAndType(clusterTag, ClusterType.PULSAR);
-        Preconditions.checkNotEmpty(clusterInfos, "pulsar cluster not exist for groupId=" + groupId);
+        Preconditions.expectNotEmpty(clusterInfos, "pulsar cluster not exist for groupId=" + groupId);
         consumeInfo.setClusterInfos(clusterInfos);
 
         // First get the tenant from the InlongGroup, and then get it from the PulsarCluster.
@@ -146,7 +146,7 @@ public class ConsumePulsarOperator extends AbstractConsumeOperator {
         String groupId = targetEntity.getInlongGroupId();
         if (dlqEnable) {
             String dlqTopic = PREFIX_DLQ + "_" + pulsarRequest.getDeadLetterTopic();
-            Preconditions.checkTrue(!streamService.exist(groupId, dlqTopic),
+            Preconditions.expectTrue(!streamService.exist(groupId, dlqTopic),
                     ErrorCodeEnum.PULSAR_DLQ_DUPLICATED.getMessage());
         } else {
             pulsarRequest.setIsDlq(DLQ__RLQ_DISABLE);
@@ -155,7 +155,7 @@ public class ConsumePulsarOperator extends AbstractConsumeOperator {
         }
         if (rlqEnable) {
             String rlqTopic = PREFIX_RLQ + "_" + pulsarRequest.getRetryLetterTopic();
-            Preconditions.checkTrue(!streamService.exist(groupId, rlqTopic),
+            Preconditions.expectTrue(!streamService.exist(groupId, rlqTopic),
                     ErrorCodeEnum.PULSAR_RLQ_DUPLICATED.getMessage());
         } else {
             pulsarRequest.setIsRlq(DLQ__RLQ_DISABLE);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumeTubeMQOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumeTubeMQOperator.java
index 8b7f7ca5f..df9cface5 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumeTubeMQOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/ConsumeTubeMQOperator.java
@@ -62,17 +62,17 @@ public class ConsumeTubeMQOperator extends AbstractConsumeOperator {
     public void checkTopicInfo(InlongConsumeRequest request) {
         String groupId = request.getInlongGroupId();
         InlongGroupTopicInfo topicInfo = groupService.getTopic(groupId);
-        Preconditions.checkNotNull(topicInfo, "inlong group not exist: " + groupId);
+        Preconditions.expectNotNull(topicInfo, "inlong group not exist: " + groupId);
 
         // one inlong group only has one TubeMQ topic
         InlongTubeMQTopicInfo tubeMQTopic = (InlongTubeMQTopicInfo) topicInfo;
-        Preconditions.checkTrue(Objects.equals(tubeMQTopic.getTopic(), request.getTopic()),
+        Preconditions.expectTrue(Objects.equals(tubeMQTopic.getTopic(), request.getTopic()),
                 String.format("topic %s for consume not belongs to inlong group %s", request.getTopic(), groupId));
     }
 
     @Override
     public InlongConsumeInfo getFromEntity(InlongConsumeEntity entity) {
-        Preconditions.checkNotNull(entity, ErrorCodeEnum.CONSUME_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(entity, ErrorCodeEnum.CONSUME_NOT_FOUND.getMessage());
 
         ConsumePulsarInfo consumeInfo = new ConsumePulsarInfo();
         CommonBeanUtils.copyProperties(entity, consumeInfo);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/InlongConsumeServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/InlongConsumeServiceImpl.java
index 6181c6cd1..6b1fb01c1 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/InlongConsumeServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/consume/InlongConsumeServiceImpl.java
@@ -68,10 +68,10 @@ public class InlongConsumeServiceImpl implements InlongConsumeService {
     @Override
     public Integer save(InlongConsumeRequest request, String operator) {
         LOGGER.debug("begin to save inlong consume={} by user={}", request, operator);
-        Preconditions.checkNotNull(request, "inlong consume request cannot be null");
-        Preconditions.checkNotNull(request.getTopic(), "inlong consume topic cannot be null");
+        Preconditions.expectNotNull(request, "inlong consume request cannot be null");
+        Preconditions.expectNotNull(request.getTopic(), "inlong consume topic cannot be null");
         String consumerGroup = request.getConsumerGroup();
-        Preconditions.checkNotNull(consumerGroup, "inlong consume topic cannot be null");
+        Preconditions.expectNotNull(consumerGroup, "inlong consume topic cannot be null");
         if (consumerGroupExists(consumerGroup, request.getId())) {
             throw new BusinessException(String.format("consumer group %s already exist", consumerGroup));
         }
@@ -130,7 +130,7 @@ public class InlongConsumeServiceImpl implements InlongConsumeService {
 
     @Override
     public InlongConsumeInfo get(Integer id) {
-        Preconditions.checkNotNull(id, "inlong consume id cannot be null");
+        Preconditions.expectNotNull(id, "inlong consume id cannot be null");
         InlongConsumeEntity entity = consumeMapper.selectById(id);
         if (entity == null) {
             LOGGER.error("inlong consume not found with id={}", id);
@@ -186,13 +186,13 @@ public class InlongConsumeServiceImpl implements InlongConsumeService {
     @Transactional(rollbackFor = Throwable.class, isolation = Isolation.REPEATABLE_READ, propagation = Propagation.REQUIRES_NEW)
     public Integer update(InlongConsumeRequest request, String operator) {
         LOGGER.debug("begin to update inlong consume={} by user={}", request, operator);
-        Preconditions.checkNotNull(request, "inlong consume request cannot be null");
+        Preconditions.expectNotNull(request, "inlong consume request cannot be null");
 
         // check if it can be modified
         Integer consumeId = request.getId();
         InlongConsumeEntity existEntity = consumeMapper.selectById(consumeId);
-        Preconditions.checkNotNull(existEntity, "inlong consume not exist with id " + consumeId);
-        Preconditions.checkTrue(existEntity.getInCharges().contains(operator),
+        Preconditions.expectNotNull(existEntity, "inlong consume not exist with id " + consumeId);
+        Preconditions.expectTrue(existEntity.getInCharges().contains(operator),
                 "operator" + operator + " has no privilege for the inlong consume");
 
         if (!Objects.equals(existEntity.getVersion(), request.getVersion())) {
@@ -202,7 +202,7 @@ public class InlongConsumeServiceImpl implements InlongConsumeService {
         }
 
         ConsumeStatus consumeStatus = ConsumeStatus.forCode(existEntity.getStatus());
-        Preconditions.checkTrue(ConsumeStatus.allowedUpdate(consumeStatus),
+        Preconditions.expectTrue(ConsumeStatus.allowedUpdate(consumeStatus),
                 "inlong consume not allowed update when status is " + consumeStatus.name());
 
         InlongConsumeOperator consumeOperator = consumeOperatorFactory.getInstance(request.getMqType());
@@ -216,7 +216,7 @@ public class InlongConsumeServiceImpl implements InlongConsumeService {
     @Transactional(rollbackFor = Throwable.class, isolation = Isolation.REPEATABLE_READ, propagation = Propagation.REQUIRES_NEW)
     public Boolean updateStatus(Integer id, Integer status, String operator) {
         LOGGER.info("begin to update consume status to [{}] for id={} by user={}", status, id, operator);
-        Preconditions.checkNotNull(id, ErrorCodeEnum.ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(id, ErrorCodeEnum.ID_IS_EMPTY.getMessage());
         InlongConsumeEntity entity = consumeMapper.selectById(id);
         if (entity == null) {
             LOGGER.error("inlong consume not found by id={}", id);
@@ -239,9 +239,9 @@ public class InlongConsumeServiceImpl implements InlongConsumeService {
     @Override
     public Boolean delete(Integer id, String operator) {
         LOGGER.info("begin to delete inlong consume for id={} by user={}", id, operator);
-        Preconditions.checkNotNull(id, "inlong consume id cannot be null");
+        Preconditions.expectNotNull(id, "inlong consume id cannot be null");
         InlongConsumeEntity entity = consumeMapper.selectById(id);
-        Preconditions.checkNotNull(entity, "inlong consume not exist with id " + id);
+        Preconditions.expectNotNull(entity, "inlong consume not exist with id " + id);
 
         entity.setIsDeleted(id);
         entity.setStatus(ConsumeStatus.DELETED.getCode());
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/AgentServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/AgentServiceImpl.java
index 24f9c90e9..ee5dabdf0 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/AgentServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/AgentServiceImpl.java
@@ -209,7 +209,7 @@ public class AgentServiceImpl implements AgentService {
         if (request.getUnbindClusterNodes() != null) {
             unbindSet.addAll(request.getUnbindClusterNodes());
         }
-        Preconditions.checkTrue(Sets.union(bindSet, unbindSet).size() == bindSet.size() + unbindSet.size(),
+        Preconditions.expectTrue(Sets.union(bindSet, unbindSet).size() == bindSet.size() + unbindSet.size(),
                 "can not add and del node tag in the sameTime");
         InlongClusterEntity cluster = clusterMapper.selectByNameAndType(request.getClusterName(), ClusterType.AGENT);
         String message = "Current user does not have permission to bind cluster node tag";
@@ -332,7 +332,7 @@ public class AgentServiceImpl implements AgentService {
                 SourceStatus.TO_BE_ISSUED_ACTIVE.getCode());
         final String agentIp = taskRequest.getAgentIp();
         final String agentClusterName = taskRequest.getClusterName();
-        Preconditions.checkTrue(StringUtils.isNotBlank(agentIp) || StringUtils.isNotBlank(agentClusterName),
+        Preconditions.expectTrue(StringUtils.isNotBlank(agentIp) || StringUtils.isNotBlank(agentClusterName),
                 "both agent ip and cluster name are blank when fetching file task");
 
         // find those node whose tag match stream_source tag and agent ip match stream_source agent ip
@@ -381,7 +381,7 @@ public class AgentServiceImpl implements AgentService {
                 SourceStatus.TO_BE_ISSUED_ACTIVE.getCode());
         final String agentIp = taskRequest.getAgentIp();
         final String agentClusterName = taskRequest.getClusterName();
-        Preconditions.checkTrue(StringUtils.isNotBlank(agentIp) || StringUtils.isNotBlank(agentClusterName),
+        Preconditions.expectTrue(StringUtils.isNotBlank(agentIp) || StringUtils.isNotBlank(agentClusterName),
                 "both agent ip and cluster name are blank when fetching file task");
 
         InlongClusterNodeEntity clusterNodeEntity = selectByIpAndCluster(agentClusterName, agentIp);
@@ -582,7 +582,7 @@ public class AgentServiceImpl implements AgentService {
     }
 
     private boolean matchGroup(StreamSourceEntity sourceEntity, InlongClusterNodeEntity clusterNodeEntity) {
-        Preconditions.checkNotNull(sourceEntity, "cluster must be valid");
+        Preconditions.expectNotNull(sourceEntity, "cluster must be valid");
         if (sourceEntity.getInlongClusterNodeGroup() == null) {
             return true;
         }
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/AuditServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/AuditServiceImpl.java
index 5c1ebe64d..10cb76df4 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/AuditServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/AuditServiceImpl.java
@@ -168,7 +168,7 @@ public class AuditServiceImpl implements AuditService {
     @Override
     public List<AuditVO> listByCondition(AuditRequest request) throws Exception {
         LOGGER.info("begin query audit list request={}", request);
-        Preconditions.checkNotNull(request, "request is null");
+        Preconditions.expectNotNull(request, "request is null");
 
         String groupId = request.getInlongGroupId();
         String streamId = request.getInlongStreamId();
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/SortServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/SortServiceImpl.java
index 31445f299..243139fc8 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/SortServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/SortServiceImpl.java
@@ -77,7 +77,7 @@ public class SortServiceImpl implements SortService, PluginBinder {
 
     @Override
     public List<SortStatusInfo> listSortStatus(SortStatusRequest request) {
-        Preconditions.checkNotNull(sortPoller, "sort status poller not initialized, please try later");
+        Preconditions.expectNotNull(sortPoller, "sort status poller not initialized, please try later");
 
         try {
             List<InlongGroupInfo> groupInfoList = request.getInlongGroupIds().stream()
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/WorkflowApproverServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/WorkflowApproverServiceImpl.java
index 3bc8290b6..17ed87021 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/WorkflowApproverServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/core/impl/WorkflowApproverServiceImpl.java
@@ -64,17 +64,17 @@ public class WorkflowApproverServiceImpl implements WorkflowApproverService {
     public Integer save(ApproverRequest request, String operator) {
         LOGGER.info("begin to save approver: {} by user: {}", request, operator);
         WorkflowProcess process = processDefinitionService.getByName(request.getProcessName());
-        Preconditions.checkNotNull(process, "process not exit with name: " + request.getProcessName());
+        Preconditions.expectNotNull(process, "process not exit with name: " + request.getProcessName());
         WorkflowTask task = process.getTaskByName(request.getTaskName());
-        Preconditions.checkNotNull(task, "task not exit with name: " + request.getTaskName());
-        Preconditions.checkTrue(task instanceof UserTask, "task should be UserTask");
+        Preconditions.expectNotNull(task, "task not exit with name: " + request.getTaskName());
+        Preconditions.expectTrue(task instanceof UserTask, "task should be UserTask");
 
         ApproverPageRequest pageRequest = ApproverPageRequest.builder()
                 .processName(request.getProcessName())
                 .taskName(request.getTaskName())
                 .build();
         List<WorkflowApproverEntity> exist = approverMapper.selectByCondition(pageRequest);
-        Preconditions.checkEmpty(exist, "workflow approver already exits");
+        Preconditions.expectEmpty(exist, "workflow approver already exits");
 
         WorkflowApproverEntity entity = CommonBeanUtils.copyProperties(request, WorkflowApproverEntity::new);
         entity.setCreator(operator);
@@ -87,7 +87,7 @@ public class WorkflowApproverServiceImpl implements WorkflowApproverService {
 
     @Override
     public ApproverResponse get(Integer id) {
-        Preconditions.checkNotNull(id, "approver id cannot be null");
+        Preconditions.expectNotNull(id, "approver id cannot be null");
         WorkflowApproverEntity approverEntity = approverMapper.selectById(id);
         if (approverEntity == null) {
             LOGGER.error("workflow approver not found by id={}", id);
@@ -123,12 +123,12 @@ public class WorkflowApproverServiceImpl implements WorkflowApproverService {
 
     @Override
     public Integer update(ApproverRequest request, String operator) {
-        Preconditions.checkNotNull(request, "approver request cannot be null");
+        Preconditions.expectNotNull(request, "approver request cannot be null");
         Integer id = request.getId();
-        Preconditions.checkNotNull(id, "approver id cannot be null");
+        Preconditions.expectNotNull(id, "approver id cannot be null");
 
         WorkflowApproverEntity entity = approverMapper.selectById(id);
-        Preconditions.checkNotNull(entity, "not exist with id:" + id);
+        Preconditions.expectNotNull(entity, "not exist with id:" + id);
         String errMsg = String.format("approver has already updated with id=%s, process=%s, task=%s, curVersion=%s",
                 id, request.getProcessName(), request.getTaskName(), request.getVersion());
         if (!Objects.equals(entity.getVersion(), request.getVersion())) {
@@ -146,9 +146,9 @@ public class WorkflowApproverServiceImpl implements WorkflowApproverService {
     @Override
     public void delete(Integer id, String operator) {
         WorkflowApproverEntity entity = approverMapper.selectById(id);
-        Preconditions.checkNotNull(entity, "not exist with id:" + id);
+        Preconditions.expectNotNull(entity, "not exist with id:" + id);
         int success = this.approverMapper.deleteByPrimaryKey(id, operator);
-        Preconditions.checkTrue(success == 1, "delete failed");
+        Preconditions.expectTrue(success == 1, "delete failed");
     }
 
 }
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/GroupCheckService.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/GroupCheckService.java
index f87f9ecc2..4ffa4f9d8 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/GroupCheckService.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/GroupCheckService.java
@@ -51,7 +51,7 @@ public class GroupCheckService {
         }
 
         List<String> managers = Arrays.asList(inlongGroupEntity.getInCharges().split(","));
-        Preconditions.checkTrue(managers.contains(operator),
+        Preconditions.expectTrue(managers.contains(operator),
                 String.format(ErrorCodeEnum.USER_IS_NOT_MANAGER.getMessage(), operator, managers));
 
         GroupStatus status = GroupStatus.forCode(inlongGroupEntity.getStatus());
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/InlongGroupProcessService.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/InlongGroupProcessService.java
index 576618983..b1e963b38 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/InlongGroupProcessService.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/InlongGroupProcessService.java
@@ -268,7 +268,7 @@ public class InlongGroupProcessService {
         LOGGER.info("begin to reset group status by operator={} for request={}", operator, request);
         final String groupId = request.getInlongGroupId();
         InlongGroupInfo groupInfo = groupService.get(groupId);
-        Preconditions.checkNotNull(groupInfo, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(groupInfo, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
 
         GroupStatus status = GroupStatus.forCode(groupInfo.getStatus());
         boolean result;
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/InlongGroupServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/InlongGroupServiceImpl.java
index 0eeb312f0..b28248d12 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/InlongGroupServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/group/InlongGroupServiceImpl.java
@@ -154,7 +154,7 @@ public class InlongGroupServiceImpl implements InlongGroupService {
     @Transactional(rollbackFor = Throwable.class)
     public String save(InlongGroupRequest request, String operator) {
         LOGGER.debug("begin to save inlong group={} by user={}", request, operator);
-        Preconditions.checkNotNull(request, "inlong group request cannot be empty");
+        Preconditions.expectNotNull(request, "inlong group request cannot be empty");
 
         String groupId = request.getInlongGroupId();
         InlongGroupEntity entity = groupMapper.selectByGroupId(groupId);
@@ -192,7 +192,7 @@ public class InlongGroupServiceImpl implements InlongGroupService {
 
     @Override
     public Boolean exist(String groupId) {
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         InlongGroupEntity entity = groupMapper.selectByGroupId(groupId);
         LOGGER.debug("success to check inlong group {}, exist? {}", groupId, entity != null);
         return entity != null;
@@ -200,7 +200,7 @@ public class InlongGroupServiceImpl implements InlongGroupService {
 
     @Override
     public InlongGroupInfo get(String groupId) {
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         InlongGroupEntity entity = groupMapper.selectByGroupId(groupId);
         if (entity == null) {
             LOGGER.error("inlong group not found by groupId={}", groupId);
@@ -454,7 +454,7 @@ public class InlongGroupServiceImpl implements InlongGroupService {
     @Transactional(rollbackFor = Throwable.class, isolation = Isolation.REPEATABLE_READ, propagation = Propagation.REQUIRES_NEW)
     public Boolean updateStatus(String groupId, Integer status, String operator) {
         LOGGER.info("begin to update group status to [{}] for groupId={} by user={}", status, groupId, operator);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         InlongGroupEntity entity = groupMapper.selectByGroupIdForUpdate(groupId);
         if (entity == null) {
             LOGGER.error("inlong group not found by groupId={}", groupId);
@@ -530,7 +530,7 @@ public class InlongGroupServiceImpl implements InlongGroupService {
     @Override
     public List<InlongGroupTopicInfo> listTopics(InlongGroupTopicRequest request) {
         LOGGER.info("start to list group topic infos, request={}", request);
-        Preconditions.checkNotEmpty(request.getClusterTag(), "cluster tag should not be empty");
+        Preconditions.expectNotEmpty(request.getClusterTag(), "cluster tag should not be empty");
         List<InlongGroupEntity> groupEntities = groupMapper.selectByTopicRequest(request);
         List<InlongGroupTopicInfo> topicInfos = new ArrayList<>();
         for (InlongGroupEntity entity : groupEntities) {
@@ -575,7 +575,7 @@ public class InlongGroupServiceImpl implements InlongGroupService {
     public Boolean delete(String groupId, String operator) {
         LOGGER.info("begin to delete inlong group for groupId={} by user={}", groupId, operator);
         InlongGroupEntity entity = groupMapper.selectByGroupId(groupId);
-        Preconditions.checkNotNull(entity, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(entity, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
 
         // before deleting an inlong group, delete all inlong streams, sources, sinks, and other info under it
         if (GroupStatus.allowedDeleteSubInfos(GroupStatus.forCode(entity.getStatus()))) {
@@ -631,7 +631,7 @@ public class InlongGroupServiceImpl implements InlongGroupService {
         String authenticationType = extMap.get(InlongConstants.SORT_AUTHENTICATION_TYPE);
         if (StringUtils.isNotBlank(authenticationType)) {
             AuthType authType = AuthType.forType(authenticationType);
-            Preconditions.checkTrue(authType == AuthType.SECRET_AND_TOKEN,
+            Preconditions.expectTrue(authType == AuthType.SECRET_AND_TOKEN,
                     "Only support SECRET_AND_TOKEN for flink sort auth");
             String authentication = extMap.get(InlongConstants.SORT_AUTHENTICATION);
             Map<String, String> authProperties = JsonUtils.parseObject(authentication,
@@ -661,10 +661,10 @@ public class InlongGroupServiceImpl implements InlongGroupService {
 
     private void chkUnmodifiableParams(InlongGroupEntity entity, InlongGroupRequest request) {
         // check mqType
-        Preconditions.chkNotEquals(entity.getMqType(), request.getMqType(),
+        Preconditions.expectEquals(entity.getMqType(), request.getMqType(),
                 ErrorCodeEnum.INVALID_PARAMETER, "mqType not allowed modify");
         // check record version
-        Preconditions.chkNotEquals(entity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(entity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         entity.getVersion(), request.getVersion()));
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/heartbeat/HeartbeatManager.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/heartbeat/HeartbeatManager.java
index 4232e4392..7b8f42e98 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/heartbeat/HeartbeatManager.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/heartbeat/HeartbeatManager.java
@@ -254,9 +254,9 @@ public class HeartbeatManager implements AbstractHeartbeatManager {
         final String type = componentHeartbeat.getComponentType();
         final String clusterTag = componentHeartbeat.getClusterTag();
         final String extTag = componentHeartbeat.getExtTag();
-        Preconditions.checkNotNull(clusterTag, "cluster tag cannot be null");
-        Preconditions.checkNotNull(type, "cluster type cannot be null");
-        Preconditions.checkNotNull(clusterName, "cluster name cannot be null");
+        Preconditions.expectNotNull(clusterTag, "cluster tag cannot be null");
+        Preconditions.expectNotNull(type, "cluster type cannot be null");
+        Preconditions.expectNotNull(clusterName, "cluster name cannot be null");
         InlongClusterEntity entity = clusterMapper.selectByNameAndType(clusterName, type);
         if (null != entity) {
             // TODO Load balancing needs to be considered.
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/heartbeat/HeartbeatServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/heartbeat/HeartbeatServiceImpl.java
index 126e3141d..475cdf179 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/heartbeat/HeartbeatServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/heartbeat/HeartbeatServiceImpl.java
@@ -93,10 +93,10 @@ public class HeartbeatServiceImpl implements HeartbeatService {
 
     @Override
     public ComponentHeartbeatResponse getComponentHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String component = request.getComponent();
-        Preconditions.checkNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
 
         ComponentTypeEnum componentType = ComponentTypeEnum.forType(component);
         switch (componentType) {
@@ -114,11 +114,11 @@ public class HeartbeatServiceImpl implements HeartbeatService {
 
     @Override
     public GroupHeartbeatResponse getGroupHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String component = request.getComponent();
-        Preconditions.checkNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         ComponentTypeEnum componentType = ComponentTypeEnum.forType(component);
         switch (componentType) {
@@ -137,12 +137,12 @@ public class HeartbeatServiceImpl implements HeartbeatService {
 
     @Override
     public StreamHeartbeatResponse getStreamHeartbeat(HeartbeatQueryRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String component = request.getComponent();
-        Preconditions.checkNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongStreamId(), ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInstance(), ErrorCodeEnum.REQUEST_INSTANCE_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInlongStreamId(), ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         ComponentTypeEnum componentType = ComponentTypeEnum.forType(component);
         switch (componentType) {
@@ -161,9 +161,9 @@ public class HeartbeatServiceImpl implements HeartbeatService {
 
     @Override
     public PageResult<ComponentHeartbeatResponse> listComponentHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String component = request.getComponent();
-        Preconditions.checkNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
 
         ComponentTypeEnum componentType = ComponentTypeEnum.forType(component);
         switch (componentType) {
@@ -180,9 +180,9 @@ public class HeartbeatServiceImpl implements HeartbeatService {
 
     @Override
     public PageResult<GroupHeartbeatResponse> listGroupHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String component = request.getComponent();
-        Preconditions.checkNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
 
         ComponentTypeEnum componentType = ComponentTypeEnum.forType(component);
         switch (componentType) {
@@ -199,10 +199,10 @@ public class HeartbeatServiceImpl implements HeartbeatService {
 
     @Override
     public PageResult<StreamHeartbeatResponse> listStreamHeartbeat(HeartbeatPageRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String component = request.getComponent();
-        Preconditions.checkNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
-        Preconditions.checkNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(component, ErrorCodeEnum.REQUEST_COMPONENT_EMPTY.getMessage());
+        Preconditions.expectNotEmpty(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         ComponentTypeEnum componentType = ComponentTypeEnum.forType(component);
         switch (componentType) {
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/listener/consume/apply/ApproveConsumeProcessListener.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/listener/consume/apply/ApproveConsumeProcessListener.java
index 4652c39d6..c32cdada6 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/listener/consume/apply/ApproveConsumeProcessListener.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/listener/consume/apply/ApproveConsumeProcessListener.java
@@ -122,9 +122,9 @@ public class ApproveConsumeProcessListener implements ProcessEventListener {
     private void createPulsarSubscription(InlongConsumeEntity entity) {
         String groupId = entity.getInlongGroupId();
         InlongGroupEntity groupEntity = groupMapper.selectByGroupId(groupId);
-        Preconditions.checkNotNull(groupEntity, "inlong group not found for groupId=" + groupId);
+        Preconditions.expectNotNull(groupEntity, "inlong group not found for groupId=" + groupId);
         String mqResource = groupEntity.getMqResource();
-        Preconditions.checkNotNull(mqResource, "mq resource cannot empty for groupId=" + groupId);
+        Preconditions.expectNotNull(mqResource, "mq resource cannot empty for groupId=" + groupId);
 
         String clusterTag = groupEntity.getInlongClusterTag();
         ClusterInfo clusterInfo = clusterService.getOne(clusterTag, null, ClusterType.PULSAR);
@@ -164,9 +164,9 @@ public class ApproveConsumeProcessListener implements ProcessEventListener {
     private void createTubeConsumerGroup(InlongConsumeEntity entity, String operator) {
         String groupId = entity.getInlongGroupId();
         InlongGroupEntity groupEntity = groupMapper.selectByGroupId(groupId);
-        Preconditions.checkNotNull(groupEntity, "inlong group not found for groupId=" + groupId);
+        Preconditions.expectNotNull(groupEntity, "inlong group not found for groupId=" + groupId);
         String mqResource = groupEntity.getMqResource();
-        Preconditions.checkNotNull(mqResource, "mq resource cannot empty for groupId=" + groupId);
+        Preconditions.expectNotNull(mqResource, "mq resource cannot empty for groupId=" + groupId);
 
         String clusterTag = groupEntity.getInlongClusterTag();
         TubeClusterInfo clusterInfo = (TubeClusterInfo) clusterService.getOne(clusterTag, null, ClusterType.TUBEMQ);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/DataNodeServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/DataNodeServiceImpl.java
index 130709ce8..0a54737c3 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/DataNodeServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/DataNodeServiceImpl.java
@@ -305,10 +305,10 @@ public class DataNodeServiceImpl implements DataNodeService {
 
     private void chkUnmodifiableParams(DataNodeEntity curEntity, DataNodeRequest request) {
         // check type
-        Preconditions.chkNotEquals(curEntity.getType(), request.getType(),
+        Preconditions.expectEquals(curEntity.getType(), request.getType(),
                 ErrorCodeEnum.INVALID_PARAMETER, "type not allowed modify");
         // check record version
-        Preconditions.chkNotEquals(curEntity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(curEntity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         curEntity.getVersion(), request.getVersion()));
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/ck/ClickHouseDataNodeOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/ck/ClickHouseDataNodeOperator.java
index 5ae29f234..7ad43b36b 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/ck/ClickHouseDataNodeOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/ck/ClickHouseDataNodeOperator.java
@@ -91,7 +91,7 @@ public class ClickHouseDataNodeOperator extends AbstractDataNodeOperator {
         String url = request.getUrl();
         String username = request.getUsername();
         String password = request.getToken();
-        Preconditions.checkNotNull(url, "connection url cannot be empty");
+        Preconditions.expectNotNull(url, "connection url cannot be empty");
         try (Connection ignored = ClickHouseJdbcUtils.getConnection(url, username, password)) {
             LOGGER.info("clickhouse connection not null - connection success for url={}, username={}, password={}", url,
                     username, password);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/es/ElasticsearchDataNodeOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/es/ElasticsearchDataNodeOperator.java
index a04e4b531..b93b2e00f 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/es/ElasticsearchDataNodeOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/es/ElasticsearchDataNodeOperator.java
@@ -89,7 +89,7 @@ public class ElasticsearchDataNodeOperator extends AbstractDataNodeOperator {
         String url = request.getUrl();
         String username = request.getUsername();
         String password = request.getToken();
-        Preconditions.checkNotNull(url, "connection url cannot be empty");
+        Preconditions.expectNotNull(url, "connection url cannot be empty");
         ElasticsearchApi client = new ElasticsearchApi();
         ElasticsearchConfig config = new ElasticsearchConfig();
         if (StringUtils.isNotEmpty(request.getUsername())) {
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/hive/HiveDataNodeOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/hive/HiveDataNodeOperator.java
index d5d6c7eb8..2ed728242 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/hive/HiveDataNodeOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/hive/HiveDataNodeOperator.java
@@ -90,7 +90,7 @@ public class HiveDataNodeOperator extends AbstractDataNodeOperator {
         String url = request.getUrl();
         String username = request.getUsername();
         String password = request.getToken();
-        Preconditions.checkNotNull(url, "connection url cannot be empty");
+        Preconditions.expectNotNull(url, "connection url cannot be empty");
         try (Connection ignored = HiveJdbcUtils.getConnection(url, username, password)) {
             LOGGER.info("hive connection not null - connection success for url={}, username={}, password={}", url,
                     username, password);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/iceberg/IcebergDataNodeOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/iceberg/IcebergDataNodeOperator.java
index 3959bdc2b..0fedeadb9 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/iceberg/IcebergDataNodeOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/iceberg/IcebergDataNodeOperator.java
@@ -88,7 +88,7 @@ public class IcebergDataNodeOperator extends AbstractDataNodeOperator {
         IcebergDataNodeRequest icebergDataNodeRequest = (IcebergDataNodeRequest) request;
         String metastoreUri = icebergDataNodeRequest.getUrl();
         String warehouse = icebergDataNodeRequest.getWarehouse();
-        Preconditions.checkNotNull(metastoreUri, "connection url cannot be empty");
+        Preconditions.expectNotNull(metastoreUri, "connection url cannot be empty");
         try {
             HiveCatalog catalog = IcebergCatalogUtils.getCatalog(metastoreUri, warehouse);
             catalog.listNamespaces();
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/mysql/MySQLDataNodeOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/mysql/MySQLDataNodeOperator.java
index 8e3f2eef8..3790197a6 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/mysql/MySQLDataNodeOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/mysql/MySQLDataNodeOperator.java
@@ -93,7 +93,7 @@ public class MySQLDataNodeOperator extends AbstractDataNodeOperator {
         String jdbcUrl = request.getUrl();
         String username = request.getUsername();
         String password = request.getToken();
-        Preconditions.checkNotNull(jdbcUrl, "connection jdbcUrl cannot be empty");
+        Preconditions.expectNotNull(jdbcUrl, "connection jdbcUrl cannot be empty");
         try (Connection ignored = MySQLJdbcUtils.getConnection(jdbcUrl, username, password)) {
             LOGGER.info("mysql connection not null - connection success for jdbcUrl={}, username={}, password={}",
                     jdbcUrl, username, password);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/starrocks/StarRocksDataNodeOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/starrocks/StarRocksDataNodeOperator.java
index 1d658d555..e63a14998 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/starrocks/StarRocksDataNodeOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/node/starrocks/StarRocksDataNodeOperator.java
@@ -90,7 +90,7 @@ public class StarRocksDataNodeOperator extends AbstractDataNodeOperator {
         String jdbcUrl = request.getUrl();
         String username = request.getUsername();
         String password = request.getToken();
-        Preconditions.checkNotNull(jdbcUrl, "connection jdbcUrl cannot be empty");
+        Preconditions.expectNotNull(jdbcUrl, "connection jdbcUrl cannot be empty");
         try (Connection ignored = StarRocksJdbcUtils.getConnection(jdbcUrl, username, password)) {
             LOGGER.info("starRocks connection not null - connection success for jdbcUrl={}, username={}, password={}",
                     jdbcUrl, username, password);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/plugin/PluginClassLoader.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/plugin/PluginClassLoader.java
index f93e2ae9a..6ed1fc350 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/plugin/PluginClassLoader.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/plugin/PluginClassLoader.java
@@ -168,9 +168,9 @@ public class PluginClassLoader extends URLClassLoader {
 
     private void checkPluginValid(File jarFile, PluginDefinition pluginDefinition) {
         String info = "[%s] not defined in plugin.yaml for " + jarFile.getName();
-        Preconditions.checkNotEmpty(pluginDefinition.getName(), String.format(info, "name"));
-        Preconditions.checkNotEmpty(pluginDefinition.getJavaVersion(), String.format(info, "javaVersion"));
-        Preconditions.checkNotEmpty(pluginDefinition.getPluginClasses(), String.format(info, "pluginClasses"));
+        Preconditions.expectNotEmpty(pluginDefinition.getName(), String.format(info, "name"));
+        Preconditions.expectNotEmpty(pluginDefinition.getJavaVersion(), String.format(info, "javaVersion"));
+        Preconditions.expectNotEmpty(pluginDefinition.getPluginClasses(), String.format(info, "pluginClasses"));
         if (StringUtils.isEmpty(pluginDefinition.getDescription())) {
             log.warn(String.format(info, "description"));
         }
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/kafka/KafkaResourceOperators.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/kafka/KafkaResourceOperators.java
index 21b0c5bdc..bae77ba9b 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/kafka/KafkaResourceOperators.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/kafka/KafkaResourceOperators.java
@@ -74,7 +74,7 @@ public class KafkaResourceOperators implements QueueResourceOperator {
 
     @Override
     public void deleteQueueForGroup(InlongGroupInfo groupInfo, String operator) {
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
 
         String groupId = groupInfo.getInlongGroupId();
         log.info("begin to delete kafka resource for groupId={}", groupId);
@@ -97,9 +97,9 @@ public class KafkaResourceOperators implements QueueResourceOperator {
 
     @Override
     public void createQueueForStream(InlongGroupInfo groupInfo, InlongStreamInfo streamInfo, String operator) {
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
-        Preconditions.checkNotNull(streamInfo, "inlong stream info cannot be null");
-        Preconditions.checkNotNull(operator, "operator cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(streamInfo, "inlong stream info cannot be null");
+        Preconditions.expectNotNull(operator, "operator cannot be null");
 
         String groupId = streamInfo.getInlongGroupId();
         String streamId = streamInfo.getInlongStreamId();
@@ -125,8 +125,8 @@ public class KafkaResourceOperators implements QueueResourceOperator {
 
     @Override
     public void deleteQueueForStream(InlongGroupInfo groupInfo, InlongStreamInfo streamInfo, String operator) {
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
-        Preconditions.checkNotNull(streamInfo, "inlong stream info cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(streamInfo, "inlong stream info cannot be null");
 
         String groupId = streamInfo.getInlongGroupId();
         String streamId = streamInfo.getInlongStreamId();
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarOperator.java
index 975c9e4bb..ec64e7867 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarOperator.java
@@ -60,7 +60,7 @@ public class PulsarOperator {
      */
     public void createTenant(PulsarAdmin pulsarAdmin, String tenant) throws PulsarAdminException {
         LOGGER.info("begin to create pulsar tenant={}", tenant);
-        Preconditions.checkNotEmpty(tenant, "Tenant cannot be empty");
+        Preconditions.expectNotEmpty(tenant, "Tenant cannot be empty");
 
         try {
             List<String> clusters = PulsarUtils.getPulsarClusters(pulsarAdmin);
@@ -85,8 +85,8 @@ public class PulsarOperator {
      */
     public void createNamespace(PulsarAdmin pulsarAdmin, InlongPulsarInfo pulsarInfo, String tenant, String namespace)
             throws PulsarAdminException {
-        Preconditions.checkNotNull(tenant, "pulsar tenant cannot be empty during create namespace");
-        Preconditions.checkNotNull(namespace, "pulsar namespace cannot be empty during create namespace");
+        Preconditions.expectNotNull(tenant, "pulsar tenant cannot be empty during create namespace");
+        Preconditions.expectNotNull(namespace, "pulsar namespace cannot be empty during create namespace");
 
         String namespaceName = tenant + "/" + namespace;
         LOGGER.info("begin to create namespace={}", namespaceName);
@@ -139,7 +139,7 @@ public class PulsarOperator {
      * Create Pulsar topic
      */
     public void createTopic(PulsarAdmin pulsarAdmin, PulsarTopicInfo topicInfo) throws PulsarAdminException {
-        Preconditions.checkNotNull(topicInfo, "pulsar topic info cannot be empty");
+        Preconditions.expectNotNull(topicInfo, "pulsar topic info cannot be empty");
         String tenant = topicInfo.getTenant();
         String namespace = topicInfo.getNamespace();
         String topicName = topicInfo.getTopicName();
@@ -195,7 +195,7 @@ public class PulsarOperator {
      * Force delete Pulsar topic
      */
     public void forceDeleteTopic(PulsarAdmin pulsarAdmin, PulsarTopicInfo topicInfo) throws PulsarAdminException {
-        Preconditions.checkNotNull(topicInfo, "pulsar topic info cannot be empty");
+        Preconditions.expectNotNull(topicInfo, "pulsar topic info cannot be empty");
 
         String tenant = topicInfo.getTenant();
         String namespace = topicInfo.getNamespace();
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarResourceOperator.java
index 4b81123d4..8334da48b 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarResourceOperator.java
@@ -77,8 +77,8 @@ public class PulsarResourceOperator implements QueueResourceOperator {
 
     @Override
     public void createQueueForGroup(InlongGroupInfo groupInfo, String operator) {
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
-        Preconditions.checkNotNull(operator, "operator cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(operator, "operator cannot be null");
 
         String groupId = groupInfo.getInlongGroupId();
         String clusterTag = groupInfo.getInlongClusterTag();
@@ -121,7 +121,7 @@ public class PulsarResourceOperator implements QueueResourceOperator {
 
     @Override
     public void deleteQueueForGroup(InlongGroupInfo groupInfo, String operator) {
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
         String groupId = groupInfo.getInlongGroupId();
         String clusterTag = groupInfo.getInlongClusterTag();
         log.info("begin to delete pulsar resource for groupId={}, clusterTag={}", groupId, clusterTag);
@@ -151,9 +151,9 @@ public class PulsarResourceOperator implements QueueResourceOperator {
 
     @Override
     public void createQueueForStream(InlongGroupInfo groupInfo, InlongStreamInfo streamInfo, String operator) {
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
-        Preconditions.checkNotNull(streamInfo, "inlong stream info cannot be null");
-        Preconditions.checkNotNull(operator, "operator cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(streamInfo, "inlong stream info cannot be null");
+        Preconditions.expectNotNull(operator, "operator cannot be null");
 
         String groupId = streamInfo.getInlongGroupId();
         String streamId = streamInfo.getInlongStreamId();
@@ -185,8 +185,8 @@ public class PulsarResourceOperator implements QueueResourceOperator {
 
     @Override
     public void deleteQueueForStream(InlongGroupInfo groupInfo, InlongStreamInfo streamInfo, String operator) {
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
-        Preconditions.checkNotNull(streamInfo, "inlong stream info cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(streamInfo, "inlong stream info cannot be null");
 
         String groupId = streamInfo.getInlongGroupId();
         String streamId = streamInfo.getInlongStreamId();
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarUtils.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarUtils.java
index 9e07427da..7d8089406 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarUtils.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/pulsar/PulsarUtils.java
@@ -41,7 +41,7 @@ public class PulsarUtils {
      * Get pulsar admin info
      */
     public static PulsarAdmin getPulsarAdmin(PulsarClusterInfo pulsarCluster) throws PulsarClientException {
-        Preconditions.checkNotNull(pulsarCluster.getAdminUrl(), "Pulsar adminUrl cannot be empty");
+        Preconditions.expectNotNull(pulsarCluster.getAdminUrl(), "Pulsar adminUrl cannot be empty");
         PulsarAdmin pulsarAdmin;
         if (StringUtils.isEmpty(pulsarCluster.getToken())) {
             pulsarAdmin = getPulsarAdmin(pulsarCluster.getAdminUrl());
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/tubemq/TubeMQResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/tubemq/TubeMQResourceOperator.java
index 3ffb96aa8..538eed9b8 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/tubemq/TubeMQResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/queue/tubemq/TubeMQResourceOperator.java
@@ -54,8 +54,8 @@ public class TubeMQResourceOperator implements QueueResourceOperator {
 
     @Override
     public void createQueueForGroup(InlongGroupInfo groupInfo, String operator) {
-        Preconditions.checkNotNull(groupInfo, "inlong group info cannot be null");
-        Preconditions.checkNotNull(operator, "operator cannot be null");
+        Preconditions.expectNotNull(groupInfo, "inlong group info cannot be null");
+        Preconditions.expectNotNull(operator, "operator cannot be null");
 
         String groupId = groupInfo.getInlongGroupId();
         log.info("begin to create pulsar resource for groupId={}", groupId);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/ck/ClickHouseResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/ck/ClickHouseResourceOperator.java
index ee3a00032..c05a94d2b 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/ck/ClickHouseResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/ck/ClickHouseResourceOperator.java
@@ -88,7 +88,7 @@ public class ClickHouseResourceOperator implements SinkResourceOperator {
         // read from data node if not supplied by user
         if (StringUtils.isBlank(ckInfo.getJdbcUrl())) {
             String dataNodeName = sinkInfo.getDataNodeName();
-            Preconditions.checkNotEmpty(dataNodeName, "clickhouse jdbc url not specified and data node is empty");
+            Preconditions.expectNotEmpty(dataNodeName, "clickhouse jdbc url not specified and data node is empty");
             ClickHouseDataNodeInfo dataNodeInfo = (ClickHouseDataNodeInfo) dataNodeHelper.getDataNodeInfo(
                     dataNodeName, sinkInfo.getSinkType());
             CommonBeanUtils.copyProperties(dataNodeInfo, ckInfo);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/hive/HiveResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/hive/HiveResourceOperator.java
index c318634f6..480a40756 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/hive/HiveResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/hive/HiveResourceOperator.java
@@ -91,7 +91,7 @@ public class HiveResourceOperator implements SinkResourceOperator {
         // read from data node if not supplied by user
         if (StringUtils.isBlank(hiveInfo.getJdbcUrl())) {
             String dataNodeName = sinkInfo.getDataNodeName();
-            Preconditions.checkNotEmpty(dataNodeName, "hive jdbc url not specified and data node is empty");
+            Preconditions.expectNotEmpty(dataNodeName, "hive jdbc url not specified and data node is empty");
             HiveDataNodeInfo dataNodeInfo = (HiveDataNodeInfo) dataNodeHelper.getDataNodeInfo(
                     dataNodeName, sinkInfo.getSinkType());
             CommonBeanUtils.copyProperties(dataNodeInfo, hiveInfo);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/hudi/HudiResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/hudi/HudiResourceOperator.java
index 17e0ed879..89c5955fe 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/hudi/HudiResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/hudi/HudiResourceOperator.java
@@ -93,7 +93,7 @@ public class HudiResourceOperator implements SinkResourceOperator {
         if (StringUtils.isBlank(hudiInfo.getCatalogUri())
                 && CATALOG_TYPE_HIVE.equals(hudiInfo.getCatalogType())) {
             String dataNodeName = sinkInfo.getDataNodeName();
-            Preconditions.checkNotEmpty(dataNodeName, "Hudi catalog uri not specified and data node is empty");
+            Preconditions.expectNotEmpty(dataNodeName, "Hudi catalog uri not specified and data node is empty");
             HudiDataNodeInfo dataNodeInfo = (HudiDataNodeInfo) dataNodeHelper.getDataNodeInfo(
                     dataNodeName, sinkInfo.getSinkType());
             CommonBeanUtils.copyProperties(dataNodeInfo, hudiInfo);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/iceberg/IcebergResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/iceberg/IcebergResourceOperator.java
index 1d1ce97bb..aa170bd26 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/iceberg/IcebergResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/iceberg/IcebergResourceOperator.java
@@ -94,7 +94,7 @@ public class IcebergResourceOperator implements SinkResourceOperator {
         if (StringUtils.isBlank(icebergInfo.getCatalogUri())
                 && CATALOG_TYPE_HIVE.equals(icebergInfo.getCatalogType())) {
             String dataNodeName = sinkInfo.getDataNodeName();
-            Preconditions.checkNotEmpty(dataNodeName, "iceberg catalog uri not specified and data node is empty");
+            Preconditions.expectNotEmpty(dataNodeName, "iceberg catalog uri not specified and data node is empty");
             IcebergDataNodeInfo dataNodeInfo = (IcebergDataNodeInfo) dataNodeHelper.getDataNodeInfo(
                     dataNodeName, sinkInfo.getSinkType());
             CommonBeanUtils.copyProperties(dataNodeInfo, icebergInfo);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/kafka/KafkaResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/kafka/KafkaResourceOperator.java
index 88e166344..1c941c463 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/kafka/KafkaResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/kafka/KafkaResourceOperator.java
@@ -64,8 +64,8 @@ public class KafkaResourceOperator implements SinkResourceOperator {
         KafkaSinkDTO kafkaInfo = KafkaSinkDTO.getFromJson(sinkInfo.getExtParams());
         String topicName = kafkaInfo.getTopicName();
         String partitionNum = kafkaInfo.getPartitionNum();
-        Preconditions.checkNotEmpty(topicName, "topic name cannot be empty");
-        Preconditions.checkNotEmpty(partitionNum, "partition cannot be empty");
+        Preconditions.expectNotEmpty(topicName, "topic name cannot be empty");
+        Preconditions.expectNotEmpty(partitionNum, "partition cannot be empty");
 
         try (Admin admin = getKafkaAdmin(kafkaInfo.getBootstrapServers())) {
             boolean topicExists = isTopicExists(admin, topicName, partitionNum);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/mysql/MySQLResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/mysql/MySQLResourceOperator.java
index fb834e3fa..e73b2e042 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/mysql/MySQLResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/mysql/MySQLResourceOperator.java
@@ -127,7 +127,7 @@ public class MySQLResourceOperator implements SinkResourceOperator {
 
         if (StringUtils.isBlank(mysqlInfo.getJdbcUrl())) {
             String dataNodeName = sinkInfo.getDataNodeName();
-            Preconditions.checkNotEmpty(dataNodeName, "mysql jdbc url not specified and data node is empty");
+            Preconditions.expectNotEmpty(dataNodeName, "mysql jdbc url not specified and data node is empty");
             DataNodeInfo dataNodeInfo = dataNodeHelper.getDataNodeInfo(dataNodeName, sinkInfo.getSinkType());
             CommonBeanUtils.copyProperties(dataNodeInfo, mysqlInfo);
             mysqlInfo.setJdbcUrl(dataNodeInfo.getUrl());
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/starrocks/StarRocksResourceOperator.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/starrocks/StarRocksResourceOperator.java
index 828bae027..4c344b114 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/starrocks/StarRocksResourceOperator.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/resource/sink/starrocks/StarRocksResourceOperator.java
@@ -144,7 +144,7 @@ public class StarRocksResourceOperator implements SinkResourceOperator {
         // read from data node if not supplied by user
         if (StringUtils.isBlank(starRocksInfo.getJdbcUrl())) {
             String dataNodeName = sinkInfo.getDataNodeName();
-            Preconditions.checkNotEmpty(dataNodeName, "starRocks jdbc url not specified and data node is empty");
+            Preconditions.expectNotEmpty(dataNodeName, "starRocks jdbc url not specified and data node is empty");
             StarRocksDataNodeInfo dataNodeInfo = (StarRocksDataNodeInfo) dataNodeHelper.getDataNodeInfo(
                     dataNodeName, sinkInfo.getSinkType());
             CommonBeanUtils.copyProperties(dataNodeInfo, starRocksInfo);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/sink/StreamSinkServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/sink/StreamSinkServiceImpl.java
index 621afda19..e2d04685b 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/sink/StreamSinkServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/sink/StreamSinkServiceImpl.java
@@ -111,7 +111,7 @@ public class StreamSinkServiceImpl implements StreamSinkService {
         String sinkName = request.getSinkName();
         // Check whether the stream exist or not
         InlongStreamEntity streamEntity = streamMapper.selectByIdentifier(groupId, streamId);
-        Preconditions.checkNotNull(streamEntity, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(streamEntity, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
 
         // Check whether the sink name exists with the same groupId and streamId
         StreamSinkEntity exists = sinkMapper.selectByUniqueKey(groupId, streamId, sinkName);
@@ -265,8 +265,8 @@ public class StreamSinkServiceImpl implements StreamSinkService {
 
     @Override
     public List<SinkBriefInfo> listBrief(String groupId, String streamId) {
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         List<SinkBriefInfo> summaryList = sinkMapper.selectSummary(groupId, streamId);
         LOGGER.debug("success to list sink summary by groupId=" + groupId + ", streamId=" + streamId);
@@ -289,7 +289,7 @@ public class StreamSinkServiceImpl implements StreamSinkService {
 
     @Override
     public PageResult<? extends StreamSink> listByCondition(SinkPageRequest request) {
-        Preconditions.checkNotNull(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         PageHelper.startPage(request.getPageNum(), request.getPageSize());
         OrderFieldEnum.checkOrderField(request);
@@ -367,7 +367,7 @@ public class StreamSinkServiceImpl implements StreamSinkService {
         // Check whether the stream exist or not
         InlongStreamEntity streamEntity = streamMapper.selectByIdentifier(
                 request.getInlongGroupId(), request.getInlongStreamId());
-        Preconditions.checkNotNull(streamEntity, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(streamEntity, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
 
         // Check whether the sink name exists with the same groupId and streamId
         StreamSinkEntity existEntity = sinkMapper.selectByUniqueKey(
@@ -496,9 +496,9 @@ public class StreamSinkServiceImpl implements StreamSinkService {
     @Transactional(rollbackFor = Throwable.class)
     public Boolean delete(Integer id, Boolean startProcess, String operator) {
         LOGGER.info("begin to delete sink by id={}", id);
-        Preconditions.checkNotNull(id, ErrorCodeEnum.ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(id, ErrorCodeEnum.ID_IS_EMPTY.getMessage());
         StreamSinkEntity entity = sinkMapper.selectByPrimaryKey(id);
-        Preconditions.checkNotNull(entity, ErrorCodeEnum.SINK_INFO_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(entity, ErrorCodeEnum.SINK_INFO_NOT_FOUND.getMessage());
 
         groupCheckService.checkGroupStatus(entity.getInlongGroupId(), operator);
 
@@ -555,11 +555,11 @@ public class StreamSinkServiceImpl implements StreamSinkService {
         LOGGER.info("begin to delete sink by groupId={}, streamId={}, sinkName={}", groupId, streamId, sinkName);
 
         // Check whether the sink name exists with the same groupId and streamId
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(sinkName, "stream sink name is empty or null");
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(sinkName, "stream sink name is empty or null");
         StreamSinkEntity entity = sinkMapper.selectByUniqueKey(groupId, streamId, sinkName);
-        Preconditions.checkNotNull(entity, String.format("stream sink not exist by groupId=%s streamId=%s sinkName=%s",
+        Preconditions.expectNotNull(entity, String.format("stream sink not exist by groupId=%s streamId=%s sinkName=%s",
                 groupId, streamId, sinkName));
 
         groupCheckService.checkGroupStatus(entity.getInlongGroupId(), operator);
@@ -579,8 +579,8 @@ public class StreamSinkServiceImpl implements StreamSinkService {
     @Transactional(rollbackFor = Throwable.class)
     public Boolean logicDeleteAll(String groupId, String streamId, String operator) {
         LOGGER.info("begin to logic delete all sink info by groupId={}, streamId={}", groupId, streamId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         // Check if it can be deleted
         groupCheckService.checkGroupStatus(groupId, operator);
@@ -612,8 +612,8 @@ public class StreamSinkServiceImpl implements StreamSinkService {
     @Transactional(rollbackFor = Throwable.class)
     public Boolean deleteAll(String groupId, String streamId, String operator) {
         LOGGER.info("begin to delete all sink by groupId={}, streamId={}", groupId, streamId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         // Check if it can be deleted
         groupCheckService.checkGroupStatus(groupId, operator);
@@ -663,7 +663,7 @@ public class StreamSinkServiceImpl implements StreamSinkService {
         for (SinkApproveDTO dto : approveList) {
             // According to the sink type, save sink information
             String sinkType = dto.getSinkType();
-            Preconditions.checkNotNull(sinkType, ErrorCodeEnum.SINK_TYPE_IS_NULL.getMessage());
+            Preconditions.expectNotNull(sinkType, ErrorCodeEnum.SINK_TYPE_IS_NULL.getMessage());
 
             StreamSinkEntity entity = sinkMapper.selectByPrimaryKey(dto.getId());
 
@@ -709,15 +709,15 @@ public class StreamSinkServiceImpl implements StreamSinkService {
     }
 
     private void checkParams(SinkRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String groupId = request.getInlongGroupId();
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         String streamId = request.getInlongStreamId();
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
         String sinkType = request.getSinkType();
-        Preconditions.checkNotNull(sinkType, ErrorCodeEnum.SINK_TYPE_IS_NULL.getMessage());
+        Preconditions.expectNotNull(sinkType, ErrorCodeEnum.SINK_TYPE_IS_NULL.getMessage());
         String sinkName = request.getSinkName();
-        Preconditions.checkNotNull(sinkName, ErrorCodeEnum.SINK_NAME_IS_NULL.getMessage());
+        Preconditions.expectNotNull(sinkName, ErrorCodeEnum.SINK_NAME_IS_NULL.getMessage());
     }
 
     private void startProcessForSink(String groupId, String streamId, String operator) {
@@ -744,10 +744,10 @@ public class StreamSinkServiceImpl implements StreamSinkService {
 
     private void chkUnmodifiableParams(StreamSinkEntity curEntity, SinkRequest request) {
         // check type
-        Preconditions.chkNotEquals(curEntity.getSinkType(), request.getSinkType(),
+        Preconditions.expectEquals(curEntity.getSinkType(), request.getSinkType(),
                 ErrorCodeEnum.INVALID_PARAMETER, "sinkType not allowed modify");
         // check record version
-        Preconditions.chkNotEquals(curEntity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(curEntity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         curEntity.getVersion(), request.getVersion()));
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/source/StreamSourceServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/source/StreamSourceServiceImpl.java
index 0e7c3c355..41890a0e8 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/source/StreamSourceServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/source/StreamSourceServiceImpl.java
@@ -215,7 +215,7 @@ public class StreamSourceServiceImpl implements StreamSourceService {
 
     @Override
     public List<StreamSource> listSource(String groupId, String streamId) {
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         List<StreamSourceEntity> entityList = sourceMapper.selectByRelatedId(groupId, streamId, null);
         if (CollectionUtils.isEmpty(entityList)) {
             return Collections.emptyList();
@@ -252,7 +252,7 @@ public class StreamSourceServiceImpl implements StreamSourceService {
 
     @Override
     public PageResult<? extends StreamSource> listByCondition(SourcePageRequest request) {
-        Preconditions.checkNotNull(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request.getInlongGroupId(), ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         PageHelper.startPage(request.getPageNum(), request.getPageSize());
         OrderFieldEnum.checkOrderField(request);
@@ -401,10 +401,10 @@ public class StreamSourceServiceImpl implements StreamSourceService {
     @Transactional(rollbackFor = Throwable.class, propagation = Propagation.REQUIRES_NEW, isolation = Isolation.READ_COMMITTED)
     public Boolean delete(Integer id, String operator) {
         LOGGER.info("begin to delete source for id={} by user={}", id, operator);
-        Preconditions.checkNotNull(id, ErrorCodeEnum.ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(id, ErrorCodeEnum.ID_IS_EMPTY.getMessage());
 
         StreamSourceEntity entity = sourceMapper.selectByIdForUpdate(id);
-        Preconditions.checkNotNull(entity, ErrorCodeEnum.SOURCE_INFO_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(entity, ErrorCodeEnum.SOURCE_INFO_NOT_FOUND.getMessage());
         boolean isTemplateSource = CollectionUtils.isNotEmpty(sourceMapper.selectByTemplateId(id));
 
         SourceStatus curStatus = SourceStatus.forCode(entity.getStatus());
@@ -488,8 +488,8 @@ public class StreamSourceServiceImpl implements StreamSourceService {
     public Boolean forceDelete(String groupId, String streamId, String operator) {
         LOGGER.info("begin to force delete source for groupId={} and streamId={} by user={}",
                 groupId, streamId, operator);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         int sourceCount = sourceMapper.updateByRelatedId(groupId, streamId, SourceStatus.TO_BE_ISSUED_DELETE.getCode());
         int fieldCount = sourceFieldMapper.updateByRelatedId(groupId, streamId);
@@ -503,7 +503,7 @@ public class StreamSourceServiceImpl implements StreamSourceService {
     public Boolean restart(Integer id, String operator) {
         LOGGER.info("begin to restart source by id={}", id);
         StreamSourceEntity entity = sourceMapper.selectByIdForUpdate(id);
-        Preconditions.checkNotNull(entity, ErrorCodeEnum.SOURCE_INFO_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(entity, ErrorCodeEnum.SOURCE_INFO_NOT_FOUND.getMessage());
 
         StreamSourceOperator sourceOperator = operatorFactory.getInstance(entity.getSourceType());
         SourceRequest sourceRequest = new SourceRequest();
@@ -519,7 +519,7 @@ public class StreamSourceServiceImpl implements StreamSourceService {
     public Boolean stop(Integer id, String operator) {
         LOGGER.info("begin to stop source by id={}", id);
         StreamSourceEntity entity = sourceMapper.selectByIdForUpdate(id);
-        Preconditions.checkNotNull(entity, ErrorCodeEnum.SOURCE_INFO_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(entity, ErrorCodeEnum.SOURCE_INFO_NOT_FOUND.getMessage());
 
         StreamSourceOperator sourceOperator = operatorFactory.getInstance(entity.getSourceType());
         SourceRequest sourceRequest = new SourceRequest();
@@ -534,7 +534,7 @@ public class StreamSourceServiceImpl implements StreamSourceService {
     @Transactional(rollbackFor = Throwable.class, propagation = Propagation.REQUIRES_NEW, isolation = Isolation.READ_COMMITTED)
     public Boolean logicDeleteAll(String groupId, String streamId, String operator) {
         LOGGER.info("begin to logic delete all source info by groupId={}, streamId={}", groupId, streamId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         // Check if it can be deleted
         Integer nextStatus = SourceStatus.TO_BE_ISSUED_DELETE.getCode();
@@ -564,8 +564,8 @@ public class StreamSourceServiceImpl implements StreamSourceService {
     @Transactional(rollbackFor = Throwable.class, propagation = Propagation.REQUIRES_NEW, isolation = Isolation.READ_COMMITTED)
     public Boolean deleteAll(String groupId, String streamId, String operator) {
         LOGGER.info("begin to delete all source by groupId={}, streamId={}", groupId, streamId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         // Check if it can be deleted
         groupCheckService.checkGroupStatus(groupId, operator);
@@ -587,15 +587,15 @@ public class StreamSourceServiceImpl implements StreamSourceService {
     }
 
     private void checkParams(SourceRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String groupId = request.getInlongGroupId();
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         String streamId = request.getInlongStreamId();
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
         String sourceType = request.getSourceType();
-        Preconditions.checkNotNull(sourceType, ErrorCodeEnum.SOURCE_TYPE_IS_NULL.getMessage());
+        Preconditions.expectNotNull(sourceType, ErrorCodeEnum.SOURCE_TYPE_IS_NULL.getMessage());
         String sourceName = request.getSourceName();
-        Preconditions.checkNotNull(sourceName, ErrorCodeEnum.SOURCE_NAME_IS_NULL.getMessage());
+        Preconditions.expectNotNull(sourceName, ErrorCodeEnum.SOURCE_NAME_IS_NULL.getMessage());
     }
 
     private void chkUnmodifiableParams(SourceRequest request) {
@@ -606,10 +606,10 @@ public class StreamSourceServiceImpl implements StreamSourceService {
                     String.format("not found source record by id=%d", request.getId()));
         }
         // check whether modify sourceType
-        Preconditions.chkNotEquals(entity.getSourceType(), request.getSourceType(),
+        Preconditions.expectEquals(entity.getSourceType(), request.getSourceType(),
                 ErrorCodeEnum.INVALID_PARAMETER, "sourceType not allowed modify");
         // check record version
-        Preconditions.chkNotEquals(entity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(entity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         entity.getVersion(), request.getVersion()));
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/stream/InlongStreamProcessService.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/stream/InlongStreamProcessService.java
index 934eb7404..e7bf8e265 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/stream/InlongStreamProcessService.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/stream/InlongStreamProcessService.java
@@ -77,7 +77,7 @@ public class InlongStreamProcessService {
         log.info("begin to start stream process for groupId={} streamId={}", groupId, streamId);
 
         InlongGroupInfo groupInfo = groupService.get(groupId);
-        Preconditions.checkNotNull(groupInfo, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(groupInfo, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
         GroupStatus groupStatus = GroupStatus.forCode(groupInfo.getStatus());
         if (groupStatus != GroupStatus.CONFIG_SUCCESSFUL && groupStatus != GroupStatus.RESTARTED) {
             throw new BusinessException(String.format("group status=%s not support start stream"
@@ -85,7 +85,7 @@ public class InlongStreamProcessService {
         }
 
         InlongStreamInfo streamInfo = streamService.get(groupId, streamId);
-        Preconditions.checkNotNull(streamInfo, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(streamInfo, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
         StreamStatus status = StreamStatus.forCode(streamInfo.getStatus());
         if (status == StreamStatus.CONFIG_ING) {
             log.warn("stream status={}, not need restart for groupId={} streamId={}", status, groupId, streamId);
@@ -119,7 +119,7 @@ public class InlongStreamProcessService {
         log.info("begin to suspend stream process for groupId={} streamId={}", groupId, streamId);
 
         InlongGroupInfo groupInfo = groupService.get(groupId);
-        Preconditions.checkNotNull(groupInfo, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(groupInfo, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
         GroupStatus groupStatus = GroupStatus.forCode(groupInfo.getStatus());
         if (!GroupStatus.allowedSuspend(groupStatus)) {
             throw new BusinessException(String.format("group status=%s not support suspend stream"
@@ -127,7 +127,7 @@ public class InlongStreamProcessService {
         }
 
         InlongStreamInfo streamInfo = streamService.get(groupId, streamId);
-        Preconditions.checkNotNull(streamInfo, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(streamInfo, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
         StreamStatus status = StreamStatus.forCode(streamInfo.getStatus());
         if (status == StreamStatus.SUSPENDED || status == StreamStatus.SUSPENDING) {
             log.warn("groupId={}, streamId={} is already in {}", groupId, streamId, status);
@@ -159,7 +159,7 @@ public class InlongStreamProcessService {
         log.info("begin to restart stream process for groupId={} streamId={}", groupId, streamId);
 
         InlongGroupInfo groupInfo = groupService.get(groupId);
-        Preconditions.checkNotNull(groupInfo, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(groupInfo, ErrorCodeEnum.GROUP_NOT_FOUND.getMessage());
         GroupStatus groupStatus = GroupStatus.forCode(groupInfo.getStatus());
         if (groupStatus != GroupStatus.CONFIG_SUCCESSFUL && groupStatus != GroupStatus.RESTARTED) {
             throw new BusinessException(
@@ -167,7 +167,7 @@ public class InlongStreamProcessService {
         }
 
         InlongStreamInfo streamInfo = streamService.get(groupId, streamId);
-        Preconditions.checkNotNull(streamInfo, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(streamInfo, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
         StreamStatus status = StreamStatus.forCode(streamInfo.getStatus());
         if (status == StreamStatus.RESTARTED || status == StreamStatus.RESTARTING) {
             log.warn("inlong stream was already in {} for groupId={}, streamId={}", status, groupId, streamId);
@@ -210,7 +210,7 @@ public class InlongStreamProcessService {
         }
 
         InlongStreamInfo streamInfo = streamService.get(groupId, streamId);
-        Preconditions.checkNotNull(streamInfo, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
+        Preconditions.expectNotNull(streamInfo, ErrorCodeEnum.STREAM_NOT_FOUND.getMessage());
         StreamStatus status = StreamStatus.forCode(streamInfo.getStatus());
         if (status == StreamStatus.DELETED || status == StreamStatus.DELETING) {
             log.debug("groupId={}, streamId={} is already in {}", groupId, streamId, status);
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/stream/InlongStreamServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/stream/InlongStreamServiceImpl.java
index 0ae06efe7..d0dffe9be 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/stream/InlongStreamServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/stream/InlongStreamServiceImpl.java
@@ -101,11 +101,11 @@ public class InlongStreamServiceImpl implements InlongStreamService {
     @Override
     public Integer save(InlongStreamRequest request, String operator) {
         LOGGER.debug("begin to save inlong stream info={}", request);
-        Preconditions.checkNotNull(request, "inlong stream info is empty");
+        Preconditions.expectNotNull(request, "inlong stream info is empty");
         String groupId = request.getInlongGroupId();
         String streamId = request.getInlongStreamId();
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         // Check if it can be added
         checkGroupStatusIsTemp(groupId);
@@ -188,8 +188,8 @@ public class InlongStreamServiceImpl implements InlongStreamService {
 
     @Override
     public Boolean exist(String groupId, String streamId) {
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
         InlongStreamEntity streamEntity = streamMapper.selectByIdentifier(groupId, streamId);
         return streamEntity != null;
     }
@@ -197,8 +197,8 @@ public class InlongStreamServiceImpl implements InlongStreamService {
     @Override
     public InlongStreamInfo get(String groupId, String streamId) {
         LOGGER.debug("begin to get inlong stream by groupId={}, streamId={}", groupId, streamId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         InlongStreamEntity streamEntity = streamMapper.selectByIdentifier(groupId, streamId);
         if (streamEntity == null) {
@@ -329,11 +329,11 @@ public class InlongStreamServiceImpl implements InlongStreamService {
     @Override
     public PageResult<InlongStreamInfo> listAll(InlongStreamPageRequest request) {
         LOGGER.debug("begin to list full inlong stream page by {}", request);
-        Preconditions.checkNotNull(request, "request is empty");
+        Preconditions.expectNotNull(request, "request is empty");
         String groupId = request.getInlongGroupId();
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         InlongGroupEntity groupEntity = groupMapper.selectByGroupId(groupId);
-        Preconditions.checkNotNull(groupEntity, "inlong group not found by groupId=" + groupId);
+        Preconditions.expectNotNull(groupEntity, "inlong group not found by groupId=" + groupId);
 
         // the person in charge of the inlong group has the authority of all inlong streams,
         // so do not filter by in charge person
@@ -372,7 +372,7 @@ public class InlongStreamServiceImpl implements InlongStreamService {
     @Override
     public List<InlongStreamBriefInfo> listBriefWithSink(String groupId) {
         LOGGER.debug("begin to get inlong stream brief list by groupId={}", groupId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         List<InlongStreamEntity> entityList = streamMapper.selectByGroupId(groupId);
         List<InlongStreamBriefInfo> briefInfoList = CommonBeanUtils
@@ -393,11 +393,11 @@ public class InlongStreamServiceImpl implements InlongStreamService {
     @Transactional(rollbackFor = Throwable.class)
     public Boolean update(InlongStreamRequest request, String operator) {
         LOGGER.debug("begin to update inlong stream info={}", request);
-        Preconditions.checkNotNull(request, "inlong stream request is empty");
+        Preconditions.expectNotNull(request, "inlong stream request is empty");
         String groupId = request.getInlongGroupId();
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         String streamId = request.getInlongStreamId();
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         // Check if it can be modified
         this.checkGroupStatusIsTemp(groupId);
@@ -413,7 +413,7 @@ public class InlongStreamServiceImpl implements InlongStreamService {
             throw new BusinessException(ErrorCodeEnum.GROUP_NOT_FOUND);
         }
         // check record version
-        Preconditions.chkNotEquals(entity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(entity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         entity.getVersion(), request.getVersion()));
@@ -504,8 +504,8 @@ public class InlongStreamServiceImpl implements InlongStreamService {
     @Transactional(rollbackFor = Throwable.class)
     public Boolean delete(String groupId, String streamId, String operator) {
         LOGGER.debug("begin to delete inlong stream, groupId={}, streamId={}", groupId, streamId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
 
         // Check if it can be deleted
         this.checkGroupStatusIsTemp(groupId);
@@ -597,7 +597,7 @@ public class InlongStreamServiceImpl implements InlongStreamService {
     @Override
     public Boolean logicDeleteAll(String groupId, String operator) {
         LOGGER.debug("begin to delete all inlong stream by groupId={}", groupId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         // Check if it can be deleted
         this.checkGroupStatusIsTemp(groupId);
@@ -644,7 +644,7 @@ public class InlongStreamServiceImpl implements InlongStreamService {
     @Override
     public List<InlongStreamBriefInfo> getTopicList(String groupId) {
         LOGGER.debug("begin bo get topic list by group id={}", groupId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
 
         List<InlongStreamBriefInfo> topicList = streamMapper.selectBriefList(groupId);
         LOGGER.debug("success to get topic list by groupId={}, result size={}", groupId, topicList.size());
@@ -781,7 +781,7 @@ public class InlongStreamServiceImpl implements InlongStreamService {
      */
     private InlongGroupEntity checkGroupStatusIsTemp(String groupId) {
         InlongGroupEntity entity = groupMapper.selectByGroupId(groupId);
-        Preconditions.checkNotNull(entity, "groupId is invalid");
+        Preconditions.expectNotNull(entity, "groupId is invalid");
         // Add/modify/delete is not allowed under temporary inlong group status
         GroupStatus curState = GroupStatus.forCode(entity.getStatus());
         if (GroupStatus.isTempStatus(curState)) {
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/transform/StreamTransformServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/transform/StreamTransformServiceImpl.java
index 2e27e96a8..b8e5e8176 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/transform/StreamTransformServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/transform/StreamTransformServiceImpl.java
@@ -141,7 +141,7 @@ public class StreamTransformServiceImpl implements StreamTransformService {
     @Override
     public List<TransformResponse> listTransform(String groupId, String streamId) {
         LOGGER.debug("begin to fetch transform info by groupId={} and streamId={} ", groupId, streamId);
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         List<StreamTransformEntity> entityList = transformMapper.selectByRelatedId(groupId, streamId, null);
         if (CollectionUtils.isEmpty(entityList)) {
             return Collections.emptyList();
@@ -223,7 +223,7 @@ public class StreamTransformServiceImpl implements StreamTransformService {
         // Check whether the transform can be modified
         String groupId = request.getInlongGroupId();
         groupCheckService.checkGroupStatus(groupId, operator);
-        Preconditions.checkNotNull(request.getId(), ErrorCodeEnum.ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request.getId(), ErrorCodeEnum.ID_IS_EMPTY.getMessage());
         StreamTransformEntity transformEntity = CommonBeanUtils.copyProperties(request,
                 StreamTransformEntity::new);
         transformEntity.setModifier(operator);
@@ -283,12 +283,12 @@ public class StreamTransformServiceImpl implements StreamTransformService {
     @Transactional(rollbackFor = Throwable.class, propagation = Propagation.REQUIRES_NEW)
     public Boolean delete(DeleteTransformRequest request, String operator) {
         LOGGER.info("begin to logic delete transform for request={}", request);
-        Preconditions.checkNotNull(request, "delete request of transform cannot be null");
+        Preconditions.expectNotNull(request, "delete request of transform cannot be null");
 
         String groupId = request.getInlongGroupId();
         String streamId = request.getInlongStreamId();
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
         groupCheckService.checkGroupStatus(groupId, operator);
 
         List<StreamTransformEntity> entityList = transformMapper.selectByRelatedId(groupId, streamId,
@@ -358,15 +358,15 @@ public class StreamTransformServiceImpl implements StreamTransformService {
     }
 
     private void checkParams(TransformRequest request) {
-        Preconditions.checkNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY.getMessage());
         String groupId = request.getInlongGroupId();
-        Preconditions.checkNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY.getMessage());
         String streamId = request.getInlongStreamId();
-        Preconditions.checkNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
+        Preconditions.expectNotNull(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY.getMessage());
         String transformType = request.getTransformType();
-        Preconditions.checkNotNull(transformType, ErrorCodeEnum.TRANSFORM_TYPE_IS_NULL.getMessage());
+        Preconditions.expectNotNull(transformType, ErrorCodeEnum.TRANSFORM_TYPE_IS_NULL.getMessage());
         String transformName = request.getTransformName();
-        Preconditions.checkNotNull(transformName, ErrorCodeEnum.TRANSFORM_NAME_IS_NULL.getMessage());
+        Preconditions.expectNotNull(transformName, ErrorCodeEnum.TRANSFORM_NAME_IS_NULL.getMessage());
     }
 
     private void chkUnmodifiableParams(TransformRequest request) {
@@ -375,7 +375,7 @@ public class StreamTransformServiceImpl implements StreamTransformService {
             throw new BusinessException(ErrorCodeEnum.TRANSFORM_NOT_FOUND);
         }
         // check record version
-        Preconditions.chkNotEquals(entity.getVersion(), request.getVersion(),
+        Preconditions.expectEquals(entity.getVersion(), request.getVersion(),
                 ErrorCodeEnum.CONFIG_EXPIRED,
                 String.format("record has expired with record version=%d, request version=%d",
                         entity.getVersion(), request.getVersion()));
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/user/UserServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/user/UserServiceImpl.java
index 963a21ef5..4e9ae89c1 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/user/UserServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/user/UserServiceImpl.java
@@ -82,8 +82,8 @@ public class UserServiceImpl implements UserService {
         String username = request.getName();
         UserEntity userExists = userMapper.selectByName(username);
         String password = request.getPassword();
-        Preconditions.checkNull(userExists, "username [" + username + "] already exists");
-        Preconditions.checkTrue(StringUtils.isNotBlank(password), "password cannot be blank");
+        Preconditions.expectNull(userExists, "username [" + username + "] already exists");
+        Preconditions.expectTrue(StringUtils.isNotBlank(password), "password cannot be blank");
 
         UserEntity entity = new UserEntity();
         entity.setName(username);
@@ -109,19 +109,19 @@ public class UserServiceImpl implements UserService {
             throw new BusinessException(errMsg);
         }
 
-        Preconditions.checkTrue(userMapper.insert(entity) > 0, "Create user failed");
+        Preconditions.expectTrue(userMapper.insert(entity) > 0, "Create user failed");
         LOGGER.debug("success to create user info={}", request);
         return entity.getId();
     }
 
     @Override
     public UserInfo getById(Integer userId, String currentUser) {
-        Preconditions.checkNotNull(userId, "User id cannot be null");
+        Preconditions.expectNotNull(userId, "User id cannot be null");
         UserEntity entity = userMapper.selectById(userId);
-        Preconditions.checkNotNull(entity, "User not exists with id " + userId);
+        Preconditions.expectNotNull(entity, "User not exists with id " + userId);
 
         UserEntity curUser = userMapper.selectByName(currentUser);
-        Preconditions.checkTrue(Objects.equals(UserTypeEnum.ADMIN.getCode(), curUser.getAccountType())
+        Preconditions.expectTrue(Objects.equals(UserTypeEnum.ADMIN.getCode(), curUser.getAccountType())
                 || Objects.equals(entity.getName(), currentUser),
                 "Current user does not have permission to get other users' info");
 
@@ -154,7 +154,7 @@ public class UserServiceImpl implements UserService {
 
     @Override
     public UserInfo getByName(String name) {
-        Preconditions.checkNotNull(name, "User name cannot be null");
+        Preconditions.expectNotNull(name, "User name cannot be null");
         UserEntity entity = userMapper.selectByName(name);
         if (entity == null) {
             return null;
@@ -183,25 +183,25 @@ public class UserServiceImpl implements UserService {
     @Override
     public Integer update(UserRequest request, String currentUser) {
         LOGGER.debug("begin to update user info={} by {}", request, currentUser);
-        Preconditions.checkNotNull(request, "Userinfo cannot be null");
-        Preconditions.checkNotNull(request.getId(), "User id cannot be null");
+        Preconditions.expectNotNull(request, "Userinfo cannot be null");
+        Preconditions.expectNotNull(request.getId(), "User id cannot be null");
 
         // Whether the current user is a manager
         UserEntity currentUserEntity = userMapper.selectByName(currentUser);
         String updateName = request.getName();
         boolean isAdmin = Objects.equals(UserTypeEnum.ADMIN.getCode(), currentUserEntity.getAccountType());
-        Preconditions.checkTrue(isAdmin || Objects.equals(updateName, currentUser),
+        Preconditions.expectTrue(isAdmin || Objects.equals(updateName, currentUser),
                 "You are not a manager and do not have permission to update other users");
 
         // manager cannot set himself as an ordinary
         boolean managerToOrdinary = isAdmin
                 && Objects.equals(UserTypeEnum.OPERATOR.getCode(), request.getAccountType())
                 && Objects.equals(currentUser, updateName);
-        Preconditions.checkFalse(managerToOrdinary, "You are a manager and you cannot change to an ordinary user");
+        Preconditions.expectFalse(managerToOrdinary, "You are a manager and you cannot change to an ordinary user");
 
         // target username must not exist
         UserEntity updateUserEntity = userMapper.selectById(request.getId());
-        Preconditions.checkNotNull(updateUserEntity, "User not exists with id=" + request.getId());
+        Preconditions.expectNotNull(updateUserEntity, "User not exists with id=" + request.getId());
         String errMsg = String.format("user has already updated with username=%s, curVersion=%s",
                 updateName, request.getVersion());
         if (!Objects.equals(updateUserEntity.getVersion(), request.getVersion())) {
@@ -210,7 +210,7 @@ public class UserServiceImpl implements UserService {
         }
 
         UserEntity targetUserEntity = userMapper.selectByName(updateName);
-        Preconditions.checkTrue(Objects.isNull(targetUserEntity)
+        Preconditions.expectTrue(Objects.isNull(targetUserEntity)
                 || Objects.equals(targetUserEntity.getName(), updateUserEntity.getName()),
                 "Username [" + updateName + "] already exists");
 
@@ -218,11 +218,11 @@ public class UserServiceImpl implements UserService {
         if (!isAdmin) {
             String oldPassword = request.getPassword();
             String oldPasswordHash = SHAUtils.encrypt(oldPassword);
-            Preconditions.checkTrue(oldPasswordHash.equals(updateUserEntity.getPassword()), "Old password is wrong");
+            Preconditions.expectTrue(oldPasswordHash.equals(updateUserEntity.getPassword()), "Old password is wrong");
             Integer validDays = DateUtils.getValidDays(updateUserEntity.getCreateTime(), updateUserEntity.getDueDate());
-            Preconditions.checkTrue((request.getValidDays() <= validDays),
+            Preconditions.expectTrue((request.getValidDays() <= validDays),
                     "Ordinary users are not allowed to add valid days");
-            Preconditions.checkTrue(Objects.equals(updateUserEntity.getAccountType(), request.getAccountType()),
+            Preconditions.expectTrue(Objects.equals(updateUserEntity.getAccountType(), request.getAccountType()),
                     "Ordinary users are not allowed to update account type");
         }
 
@@ -247,14 +247,14 @@ public class UserServiceImpl implements UserService {
 
     @Override
     public Boolean delete(Integer userId, String currentUser) {
-        Preconditions.checkNotNull(userId, "User id should not be empty");
+        Preconditions.expectNotNull(userId, "User id should not be empty");
 
         // Whether the current user is an administrator
         UserEntity curUser = userMapper.selectByName(currentUser);
         UserEntity entity = userMapper.selectById(userId);
-        Preconditions.checkTrue(curUser.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
+        Preconditions.expectTrue(curUser.getAccountType().equals(UserTypeEnum.ADMIN.getCode()),
                 "Current user is not a manager and does not have permission to delete users");
-        Preconditions.checkTrue(!Objects.equals(entity.getName(), currentUser),
+        Preconditions.expectTrue(!Objects.equals(entity.getName(), currentUser),
                 "Current user does not have permission to delete himself");
         userMapper.deleteById(userId);
 
diff --git a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/workflow/WorkflowServiceImpl.java b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/workflow/WorkflowServiceImpl.java
index 0a4679d0c..8d14b3195 100644
--- a/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/workflow/WorkflowServiceImpl.java
+++ b/inlong-manager/manager-service/src/main/java/org/apache/inlong/manager/service/workflow/WorkflowServiceImpl.java
@@ -180,12 +180,12 @@ public class WorkflowServiceImpl implements WorkflowService {
 
     @Override
     public PageResult<WorkflowExecuteLog> listTaskLogs(TaskLogRequest query) {
-        Preconditions.checkNotNull(query, "task execute log query params cannot be null");
+        Preconditions.expectNotNull(query, "task execute log query params cannot be null");
 
         String groupId = query.getInlongGroupId();
         List<String> processNameList = query.getProcessNames();
-        Preconditions.checkNotEmpty(groupId, "inlong group id cannot be null");
-        Preconditions.checkNotEmpty(processNameList, "process name list cannot be null");
+        Preconditions.expectNotEmpty(groupId, "inlong group id cannot be null");
+        Preconditions.expectNotEmpty(processNameList, "process name list cannot be null");
 
         ProcessRequest processRequest = new ProcessRequest();
         processRequest.setInlongGroupId(groupId);
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/openapi/OpenAPIAuthenticatingRealm.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/openapi/OpenAPIAuthenticatingRealm.java
index 91fbbdce6..00ee32ada 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/openapi/OpenAPIAuthenticatingRealm.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/openapi/OpenAPIAuthenticatingRealm.java
@@ -55,8 +55,8 @@ public class OpenAPIAuthenticatingRealm extends AuthenticatingRealm {
         SecretToken upToken = (SecretToken) authenticationToken;
         String username = upToken.getSecretId();
         UserInfo userInfo = userService.getByName(username);
-        Preconditions.checkNotNull(userInfo, "User doesn't exist");
-        Preconditions.checkTrue(userInfo.getDueDate().after(new Date()), "user has expired");
+        Preconditions.expectNotNull(userInfo, "User doesn't exist");
+        Preconditions.expectTrue(userInfo.getDueDate().after(new Date()), "user has expired");
         try {
             String secretKey = new String(
                     AESUtils.decryptAsString(userInfo.getSecretKey(), userInfo.getEncryptVersion()));
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/web/AuthenticationFilter.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/web/AuthenticationFilter.java
index 5408daefc..74aad7dad 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/web/AuthenticationFilter.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/web/AuthenticationFilter.java
@@ -97,8 +97,8 @@ public class AuthenticationFilter implements Filter {
     private UsernamePasswordToken getPasswordToken(ServletRequest servletRequest) {
         String username = servletRequest.getParameter(USERNAME);
         String password = servletRequest.getParameter(PASSWORD);
-        Preconditions.checkNotNull(username, "please input username");
-        Preconditions.checkNotNull(password, "please input password");
+        Preconditions.expectNotNull(username, "please input username");
+        Preconditions.expectNotNull(password, "please input password");
         return new UsernamePasswordToken(username, password);
     }
 
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/web/WebAuthorizingRealm.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/web/WebAuthorizingRealm.java
index 230290bea..7f5f06dbb 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/web/WebAuthorizingRealm.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/auth/web/WebAuthorizingRealm.java
@@ -53,8 +53,8 @@ public class WebAuthorizingRealm extends AuthorizingRealm {
         UsernamePasswordToken upToken = (UsernamePasswordToken) token;
         String username = upToken.getUsername();
         UserInfo userInfo = userService.getByName(username);
-        Preconditions.checkNotNull(userInfo, "User not exist with name=" + username);
-        Preconditions.checkTrue(userInfo.getDueDate().after(new Date()), "User " + username + " was expired");
+        Preconditions.expectNotNull(userInfo, "User not exist with name=" + username);
+        Preconditions.expectTrue(userInfo.getDueDate().after(new Date()), "User " + username + " was expired");
         userInfo.setRoles(Sets.newHashSet(userInfo.getAccountType() == 0
                 ? UserTypeEnum.ADMIN.name()
                 : UserTypeEnum.OPERATOR.name()));
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenDataNodeController.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenDataNodeController.java
index bd32fbda6..caa98f2bc 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenDataNodeController.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenDataNodeController.java
@@ -60,16 +60,16 @@ public class OpenDataNodeController {
     @ApiOperation(value = "Get node by id")
     @ApiImplicitParam(name = "id", value = "Data node ID", dataTypeClass = Integer.class, required = true)
     public Response<DataNodeInfo> get(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.ID_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "data node id cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(dataNodeService.get(id, LoginUserUtils.getLoginUser()));
     }
 
     @PostMapping(value = "/node/list")
     @ApiOperation(value = "List data node")
     public Response<List<DataNodeInfo>> list(@RequestBody DataNodePageRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(dataNodeService.list(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -77,8 +77,8 @@ public class OpenDataNodeController {
     @ApiOperation(value = "Save node")
     @OperationLog(operation = OperationType.CREATE)
     public Response<Integer> save(@Validated(SaveValidation.class) @RequestBody DataNodeRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(dataNodeService.save(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -86,8 +86,8 @@ public class OpenDataNodeController {
     @ApiOperation(value = "Update data node")
     @OperationLog(operation = OperationType.UPDATE)
     public Response<Boolean> update(@Validated(UpdateByIdValidation.class) @RequestBody DataNodeRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.REQUEST_IS_EMPTY);
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(dataNodeService.update(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -96,8 +96,8 @@ public class OpenDataNodeController {
     @OperationLog(operation = OperationType.DELETE)
     @ApiImplicitParam(name = "id", value = "Data node ID", dataTypeClass = Integer.class, required = true)
     public Response<Boolean> delete(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.ID_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "data node id cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(dataNodeService.delete(id, LoginUserUtils.getLoginUser()));
     }
 }
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongClusterController.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongClusterController.java
index 2bfb3b059..d338d2abd 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongClusterController.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongClusterController.java
@@ -70,16 +70,16 @@ public class OpenInLongClusterController {
     @ApiOperation(value = "Get cluster tag by id")
     @ApiImplicitParam(name = "id", value = "Cluster ID", dataTypeClass = Integer.class, required = true)
     public Response<ClusterTagResponse> getTag(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "tag id cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "tag id cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.getTag(id, LoginUserUtils.getLoginUser()));
     }
 
     @PostMapping(value = "/cluster/tag/list")
     @ApiOperation(value = "List cluster tags")
     public Response<List<ClusterTagResponse>> listTag(@RequestBody ClusterTagPageRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.listTag(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -87,8 +87,8 @@ public class OpenInLongClusterController {
     @ApiOperation(value = "Save cluster tag")
     @OperationLog(operation = OperationType.CREATE)
     public Response<Integer> saveTag(@Validated(SaveValidation.class) @RequestBody ClusterTagRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.saveTag(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -96,8 +96,8 @@ public class OpenInLongClusterController {
     @OperationLog(operation = OperationType.UPDATE)
     @ApiOperation(value = "Update cluster tag")
     public Response<Boolean> updateTag(@Validated(UpdateValidation.class) @RequestBody ClusterTagRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.updateTag(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -106,8 +106,8 @@ public class OpenInLongClusterController {
     @OperationLog(operation = OperationType.DELETE)
     @ApiImplicitParam(name = "id", value = "Cluster tag ID", dataTypeClass = Integer.class, required = true)
     public Response<Boolean> deleteTag(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "tag id cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "tag id cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.deleteTag(id, LoginUserUtils.getLoginUser()));
     }
 
@@ -115,16 +115,16 @@ public class OpenInLongClusterController {
     @ApiOperation(value = "Get cluster by id")
     @ApiImplicitParam(name = "id", value = "Cluster ID", dataTypeClass = Integer.class, required = true)
     public Response<ClusterInfo> get(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "cluster id cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "cluster id cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.get(id, LoginUserUtils.getLoginUser()));
     }
 
     @PostMapping(value = "/cluster/list")
     @ApiOperation(value = "List clusters")
     public Response<List<ClusterInfo>> list(@RequestBody ClusterPageRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.list(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -132,8 +132,8 @@ public class OpenInLongClusterController {
     @ApiOperation(value = "Save cluster")
     @OperationLog(operation = OperationType.CREATE)
     public Response<Integer> save(@Validated(SaveValidation.class) @RequestBody ClusterRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.save(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -141,8 +141,8 @@ public class OpenInLongClusterController {
     @ApiOperation(value = "Update cluster")
     @OperationLog(operation = OperationType.UPDATE)
     public Response<Boolean> update(@Validated(UpdateByIdValidation.class) @RequestBody ClusterRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.update(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -150,8 +150,8 @@ public class OpenInLongClusterController {
     @ApiOperation(value = "Bind or unbind cluster tag")
     @OperationLog(operation = OperationType.UPDATE)
     public Response<Boolean> bindTag(@Validated @RequestBody BindTagRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.bindTag(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -160,8 +160,8 @@ public class OpenInLongClusterController {
     @OperationLog(operation = OperationType.DELETE)
     @ApiImplicitParam(name = "id", value = "Cluster ID", dataTypeClass = Integer.class, required = true)
     public Response<Boolean> delete(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "cluster id cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "cluster id cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.delete(id, LoginUserUtils.getLoginUser()));
     }
 
@@ -169,16 +169,16 @@ public class OpenInLongClusterController {
     @ApiOperation(value = "Get cluster node by id")
     @ApiImplicitParam(name = "id", value = "Cluster node ID", dataTypeClass = Integer.class, required = true)
     public Response<ClusterNodeResponse> getNode(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "Cluster node id cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "Cluster node id cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.getNode(id, LoginUserUtils.getLoginUser()));
     }
 
     @PostMapping(value = "/cluster/node/list")
     @ApiOperation(value = "List cluster nodes")
     public Response<List<ClusterNodeResponse>> listNode(@RequestBody ClusterPageRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.listNode(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -192,9 +192,9 @@ public class OpenInLongClusterController {
     @OperationLog(operation = OperationType.GET)
     public Response<List<ClusterNodeResponse>> listByGroupId(@RequestParam String inlongGroupId,
             @RequestParam String clusterType, @RequestParam(required = false) String protocolType) {
-        Preconditions.checkBlank(inlongGroupId, ErrorCodeEnum.INVALID_PARAMETER, "inlongGroupId cannot be null");
-        Preconditions.checkBlank(clusterType, ErrorCodeEnum.INVALID_PARAMETER, "clusterType cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotBlank(inlongGroupId, ErrorCodeEnum.INVALID_PARAMETER, "inlongGroupId cannot be blank");
+        Preconditions.expectNotBlank(clusterType, ErrorCodeEnum.INVALID_PARAMETER, "clusterType cannot be blank");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.listNodeByGroupId(inlongGroupId,
                 clusterType, protocolType, LoginUserUtils.getLoginUser()));
     }
@@ -203,8 +203,8 @@ public class OpenInLongClusterController {
     @ApiOperation(value = "Save cluster node")
     @OperationLog(operation = OperationType.CREATE)
     public Response<Integer> saveNode(@Validated @RequestBody ClusterNodeRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.saveNode(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -212,8 +212,8 @@ public class OpenInLongClusterController {
     @OperationLog(operation = OperationType.UPDATE)
     @ApiOperation(value = "Update cluster node")
     public Response<Boolean> updateNode(@Validated(UpdateValidation.class) @RequestBody ClusterNodeRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.updateNode(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -222,8 +222,8 @@ public class OpenInLongClusterController {
     @OperationLog(operation = OperationType.DELETE)
     @ApiImplicitParam(name = "id", value = "Cluster node ID", dataTypeClass = Integer.class, required = true)
     public Response<Boolean> deleteNode(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "cluster id cannot be null");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "cluster id cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(clusterService.deleteNode(id, LoginUserUtils.getLoginUser()));
     }
 
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongGroupController.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongGroupController.java
index c279997a5..2f3d6888f 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongGroupController.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongGroupController.java
@@ -65,17 +65,16 @@ public class OpenInLongGroupController {
     @ApiOperation(value = "Get InLong group information by groupId")
     @ApiImplicitParam(name = "groupId", value = "InLong Group ID", dataTypeClass = String.class, required = true)
     public Response<InlongGroupInfo> get(@PathVariable String groupId) {
-        Preconditions.checkBlank(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotBlank(groupId, ErrorCodeEnum.INVALID_PARAMETER, "groupId cannot be blank");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(groupService.get(groupId, LoginUserUtils.getLoginUser()));
     }
 
     @PostMapping(value = "/group/list")
     @ApiOperation(value = "List inlong groups by paginating")
     public Response<List<InlongGroupBriefInfo>> listBrief(@RequestBody InlongGroupPageRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER,
-                "group query request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(groupService.listBrief(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -83,9 +82,8 @@ public class OpenInLongGroupController {
     @OperationLog(operation = OperationType.CREATE)
     @ApiOperation(value = "Save inlong group")
     public Response<String> save(@Validated(SaveValidation.class) @RequestBody InlongGroupRequest groupRequest) {
-        Preconditions.checkNull(groupRequest, ErrorCodeEnum.REQUEST_IS_EMPTY,
-                "inlong group request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(groupRequest, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(groupService.save(groupRequest, LoginUserUtils.getLoginUser()));
     }
 
@@ -93,9 +91,8 @@ public class OpenInLongGroupController {
     @OperationLog(operation = OperationType.UPDATE)
     @ApiOperation(value = "Update inlong group")
     public Response<String> update(@Validated(UpdateValidation.class) @RequestBody InlongGroupRequest groupRequest) {
-        Preconditions.checkNull(groupRequest, ErrorCodeEnum.REQUEST_IS_EMPTY,
-                "group query request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(groupRequest, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(groupService.update(groupRequest, LoginUserUtils.getLoginUser()));
     }
 
@@ -104,9 +101,8 @@ public class OpenInLongGroupController {
     @OperationLog(operation = OperationType.DELETE)
     @ApiImplicitParam(name = "groupId", value = "Inlong group id", dataTypeClass = String.class, required = true)
     public Response<Boolean> delete(@PathVariable String groupId) {
-        Preconditions.checkBlank(groupId, ErrorCodeEnum.INVALID_PARAMETER,
-                "inlong group id in request cannot be blank");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotBlank(groupId, ErrorCodeEnum.INVALID_PARAMETER, "groupId cannot be blank");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(groupProcessOperation.deleteProcess(groupId, LoginUserUtils.getLoginUser()));
     }
 }
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongStreamController.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongStreamController.java
index 92786b1b2..acf2664c2 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongStreamController.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenInLongStreamController.java
@@ -62,18 +62,17 @@ public class OpenInLongStreamController {
             @ApiImplicitParam(name = "streamId", dataTypeClass = String.class, required = true)
     })
     public Response<InlongStreamInfo> get(@RequestParam String groupId, @RequestParam String streamId) {
-        Preconditions.checkBlank(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY);
-        Preconditions.checkBlank(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotBlank(groupId, ErrorCodeEnum.INVALID_PARAMETER, "groupId cannot be blank");
+        Preconditions.expectNotBlank(streamId, ErrorCodeEnum.INVALID_PARAMETER, "streamId cannot be blank");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(streamService.get(groupId, streamId, LoginUserUtils.getLoginUser()));
     }
 
     @RequestMapping(value = "/stream/list", method = RequestMethod.POST)
     @ApiOperation(value = "List inlong stream briefs by paginating")
     public Response<List<InlongStreamBriefInfo>> listByCondition(@RequestBody InlongStreamPageRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER,
-                "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(streamService.listBrief(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -81,9 +80,8 @@ public class OpenInLongStreamController {
     @OperationLog(operation = OperationType.CREATE)
     @ApiOperation(value = "Save inlong stream")
     public Response<Integer> save(@RequestBody InlongStreamRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER,
-                "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(streamService.save(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -91,9 +89,8 @@ public class OpenInLongStreamController {
     @OperationLog(operation = OperationType.UPDATE)
     @ApiOperation(value = "Update inlong stream")
     public Response<Boolean> update(@Validated(UpdateValidation.class) @RequestBody InlongStreamRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER,
-                "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(streamService.update(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -105,9 +102,9 @@ public class OpenInLongStreamController {
             @ApiImplicitParam(name = "streamId", dataTypeClass = String.class, required = true)
     })
     public Response<Boolean> delete(@RequestParam String groupId, @RequestParam String streamId) {
-        Preconditions.checkBlank(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY);
-        Preconditions.checkBlank(streamId, ErrorCodeEnum.STREAM_ID_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotBlank(groupId, ErrorCodeEnum.INVALID_PARAMETER, "groupId cannot be blank");
+        Preconditions.expectNotBlank(streamId, ErrorCodeEnum.INVALID_PARAMETER, "streamId cannot be blank");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(streamService.delete(groupId, streamId, LoginUserUtils.getLoginUser()));
     }
 }
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamSinkController.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamSinkController.java
index b8561668d..0e5feeec9 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamSinkController.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamSinkController.java
@@ -59,16 +59,16 @@ public class OpenStreamSinkController {
     @ApiOperation(value = "Get stream sink")
     @ApiImplicitParam(name = "id", dataTypeClass = Integer.class, required = true)
     public Response<StreamSink> get(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "sink id is empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "sinkId cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sinkService.get(id, LoginUserUtils.getLoginUser()));
     }
 
     @RequestMapping(value = "/sink/list", method = RequestMethod.GET)
     @ApiOperation(value = "List stream sinks by paginating")
     public Response<List<? extends StreamSink>> listByCondition(SinkPageRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sinkService.listByCondition(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -76,8 +76,8 @@ public class OpenStreamSinkController {
     @OperationLog(operation = OperationType.CREATE)
     @ApiOperation(value = "Save stream sink")
     public Response<Integer> save(@Validated @RequestBody SinkRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sinkService.save(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -85,8 +85,8 @@ public class OpenStreamSinkController {
     @OperationLog(operation = OperationType.UPDATE)
     @ApiOperation(value = "Update stream sink")
     public Response<Boolean> update(@Validated(UpdateByIdValidation.class) @RequestBody SinkRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sinkService.update(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -99,8 +99,8 @@ public class OpenStreamSinkController {
     })
     public Response<Boolean> delete(@PathVariable Integer id,
             @RequestParam(required = false, defaultValue = "false") boolean startProcess) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "sink id is empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "sinkId cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sinkService.delete(id, startProcess, LoginUserUtils.getLoginUser()));
     }
 }
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamSourceController.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamSourceController.java
index a53d9aff6..27c30ab41 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamSourceController.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamSourceController.java
@@ -57,16 +57,16 @@ public class OpenStreamSourceController {
     @ApiOperation(value = "Get stream source")
     @ApiImplicitParam(name = "id", dataTypeClass = Integer.class, required = true)
     public Response<StreamSource> get(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "source id is empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "sourceId cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sourceService.get(id, LoginUserUtils.getLoginUser()));
     }
 
     @RequestMapping(value = "/source/list", method = RequestMethod.GET)
     @ApiOperation(value = "List stream sources by paginating")
     public Response<PageResult<? extends StreamSource>> listByCondition(SourcePageRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sourceService.listByCondition(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -74,8 +74,8 @@ public class OpenStreamSourceController {
     @OperationLog(operation = OperationType.CREATE)
     @ApiOperation(value = "Save stream source")
     public Response<Integer> save(@Validated(SaveValidation.class) @RequestBody SourceRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sourceService.save(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -83,8 +83,8 @@ public class OpenStreamSourceController {
     @OperationLog(operation = OperationType.UPDATE)
     @ApiOperation(value = "Update stream source")
     public Response<Boolean> update(@Validated(UpdateValidation.class) @RequestBody SourceRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sourceService.update(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -93,8 +93,8 @@ public class OpenStreamSourceController {
     @ApiOperation(value = "Delete stream source")
     @ApiImplicitParam(name = "id", dataTypeClass = Integer.class, required = true)
     public Response<Boolean> delete(@PathVariable Integer id) {
-        Preconditions.checkNull(id, ErrorCodeEnum.INVALID_PARAMETER, "source id is empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(id, ErrorCodeEnum.INVALID_PARAMETER, "sourceId cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(sourceService.delete(id, LoginUserUtils.getLoginUser()));
     }
 }
diff --git a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamTransformController.java b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamTransformController.java
index b9efd2a07..8f3ff1162 100644
--- a/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamTransformController.java
+++ b/inlong-manager/manager-web/src/main/java/org/apache/inlong/manager/web/controller/openapi/OpenStreamTransformController.java
@@ -56,8 +56,8 @@ public class OpenStreamTransformController {
     @ApiOperation(value = "Get stream transform list")
     public Response<List<TransformResponse>> list(@RequestParam("inlongGroupId") String groupId,
             @RequestParam("inlongStreamId") String streamId) {
-        Preconditions.checkBlank(groupId, ErrorCodeEnum.GROUP_ID_IS_EMPTY);
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotBlank(groupId, ErrorCodeEnum.INVALID_PARAMETER, "groupId cannot be blank");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(streamTransformService.listTransform(
                 groupId, streamId, LoginUserUtils.getLoginUser()));
     }
@@ -66,8 +66,8 @@ public class OpenStreamTransformController {
     @OperationLog(operation = OperationType.CREATE)
     @ApiOperation(value = "Save stream transform")
     public Response<Integer> save(@Validated @RequestBody TransformRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(
                 streamTransformService.save(request, LoginUserUtils.getLoginUser()));
     }
@@ -76,8 +76,8 @@ public class OpenStreamTransformController {
     @OperationLog(operation = OperationType.UPDATE)
     @ApiOperation(value = "Update stream transform")
     public Response<Boolean> update(@Validated(UpdateValidation.class) @RequestBody TransformRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(streamTransformService.update(request, LoginUserUtils.getLoginUser()));
     }
 
@@ -85,8 +85,8 @@ public class OpenStreamTransformController {
     @OperationLog(operation = OperationType.UPDATE)
     @ApiOperation(value = "Delete stream transform")
     public Response<Boolean> delete(@Validated DeleteTransformRequest request) {
-        Preconditions.checkNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be empty");
-        Preconditions.checkNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
+        Preconditions.expectNotNull(request, ErrorCodeEnum.INVALID_PARAMETER, "request cannot be null");
+        Preconditions.expectNotNull(LoginUserUtils.getLoginUser(), ErrorCodeEnum.LOGIN_USER_EMPTY);
         return Response.success(streamTransformService.delete(request, LoginUserUtils.getLoginUser()));
     }
 }
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/EventListenerServiceImpl.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/EventListenerServiceImpl.java
index 84ed50428..5244882cc 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/EventListenerServiceImpl.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/EventListenerServiceImpl.java
@@ -55,7 +55,7 @@ public class EventListenerServiceImpl implements EventListenerService {
     @Override
     public void executeEventListener(Integer eventLogId) {
         WorkflowEventLogEntity eventLogEntity = eventLogMapper.selectById(eventLogId);
-        Preconditions.checkNotNull(eventLogEntity, "event log not exist with id: " + eventLogId);
+        Preconditions.expectNotNull(eventLogEntity, "event log not exist with id: " + eventLogId);
         if (ProcessEvent.class.getSimpleName().equals(eventLogEntity.getEventType())) {
             this.executeProcessEventListener(eventLogEntity.getProcessId(), eventLogEntity.getListener());
             return;
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/MemoryProcessDefinitionRepository.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/MemoryProcessDefinitionRepository.java
index 291f2876b..2add6a1be 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/MemoryProcessDefinitionRepository.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/MemoryProcessDefinitionRepository.java
@@ -49,7 +49,7 @@ public class MemoryProcessDefinitionRepository implements ProcessDefinitionRepos
 
     @Override
     public void add(WorkflowProcess process) {
-        Preconditions.checkNotEmpty(process.getName(), "process name cannot be null");
+        Preconditions.expectNotEmpty(process.getName(), "process name cannot be null");
         if (PROCESS_BY_NAME_MAP.containsKey(process.getName())) {
             throw new WorkflowException("process already exist with the same name " + process.getName());
         }
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/ProcessDefinitionServiceImpl.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/ProcessDefinitionServiceImpl.java
index 38bb8a68a..73d11dc48 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/ProcessDefinitionServiceImpl.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/ProcessDefinitionServiceImpl.java
@@ -35,7 +35,7 @@ public class ProcessDefinitionServiceImpl implements ProcessDefinitionService {
 
     @Override
     public void register(WorkflowProcess process) {
-        Preconditions.checkNotNull(process, "process cannot be null");
+        Preconditions.expectNotNull(process, "process cannot be null");
         process.validate();
         definitionRepository.add(process);
     }
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/ProcessServiceImpl.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/ProcessServiceImpl.java
index bae2bf691..65319c1c9 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/ProcessServiceImpl.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/ProcessServiceImpl.java
@@ -53,9 +53,9 @@ public class ProcessServiceImpl implements ProcessService {
 
     @Override
     public WorkflowContext start(String name, String applicant, ProcessForm form) {
-        Preconditions.checkNotEmpty(name, "process name cannot be null");
-        Preconditions.checkNotEmpty(applicant, "applicant cannot be null");
-        Preconditions.checkNotNull(form, "form cannot be null");
+        Preconditions.expectNotEmpty(name, "process name cannot be null");
+        Preconditions.expectNotEmpty(applicant, "applicant cannot be null");
+        Preconditions.expectNotNull(form, "form cannot be null");
 
         // build context
         WorkflowContext context = workflowContextBuilder.buildContextForProcess(name, applicant, form);
@@ -65,12 +65,12 @@ public class ProcessServiceImpl implements ProcessService {
 
     @Override
     public WorkflowContext continueProcess(Integer processId, String operator, String remark) {
-        Preconditions.checkNotEmpty(operator, "operator cannot be null");
-        Preconditions.checkNotNull(processId, "processId cannot be null");
+        Preconditions.expectNotEmpty(operator, "operator cannot be null");
+        Preconditions.expectNotNull(processId, "processId cannot be null");
         WorkflowContext context = workflowContextBuilder.buildContextForProcess(processId);
         WorkflowProcessEntity processEntity = context.getProcessEntity();
         ProcessStatus processStatus = ProcessStatus.valueOf(processEntity.getStatus());
-        Preconditions.checkTrue(processStatus == ProcessStatus.PROCESSING,
+        Preconditions.expectTrue(processStatus == ProcessStatus.PROCESSING,
                 String.format("processId=%s should be in processing", processId));
         List<WorkflowTaskEntity> startElements = Lists.newArrayList();
         startElements.addAll(taskEntityMapper.selectByProcess(processId, TaskStatus.PENDING));
@@ -91,8 +91,8 @@ public class ProcessServiceImpl implements ProcessService {
 
     @Override
     public WorkflowContext cancel(Integer processId, String operator, String remark) {
-        Preconditions.checkNotEmpty(operator, "operator cannot be null");
-        Preconditions.checkNotNull(processId, "processId cannot be null");
+        Preconditions.expectNotEmpty(operator, "operator cannot be null");
+        Preconditions.expectNotNull(processId, "processId cannot be null");
 
         WorkflowContext context = workflowContextBuilder.buildContextForProcess(processId);
         List<WorkflowTaskEntity> pendingTasks = taskEntityMapper.selectByProcess(processId, TaskStatus.PENDING);
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/WorkflowContextBuilderImpl.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/WorkflowContextBuilderImpl.java
index e9da80e1f..522ffbd42 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/WorkflowContextBuilderImpl.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/core/impl/WorkflowContextBuilderImpl.java
@@ -75,7 +75,7 @@ public class WorkflowContextBuilderImpl implements WorkflowContextBuilder {
     @Override
     public WorkflowContext buildContextForProcess(Integer processId) {
         WorkflowProcessEntity processEntity = processEntityMapper.selectById(processId);
-        Preconditions.checkNotNull(processEntity, "process not exist with id: " + processId);
+        Preconditions.expectNotNull(processEntity, "process not exist with id: " + processId);
         WorkflowProcess process = definitionRepository.get(processEntity.getName()).clone();
 
         return new WorkflowContext()
@@ -117,7 +117,7 @@ public class WorkflowContextBuilderImpl implements WorkflowContextBuilder {
     private WorkflowContext buildContextForTask(Integer taskId, WorkflowAction action, TaskForm taskForm,
             List<String> transferToUsers, String remark, String operator) {
         WorkflowTaskEntity taskEntity = taskEntityMapper.selectById(taskId);
-        Preconditions.checkNotNull(taskEntity, "task not exist with id: " + taskId);
+        Preconditions.expectNotNull(taskEntity, "task not exist with id: " + taskId);
 
         WorkflowProcessEntity processEntity = processEntityMapper.selectById(taskEntity.getProcessId());
         WorkflowProcess process = definitionRepository.get(processEntity.getName()).clone();
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/Element.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/Element.java
index 9e089fdf8..a99c16d4a 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/Element.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/Element.java
@@ -36,8 +36,8 @@ public abstract class Element implements Cloneable {
     }
 
     public void validate() {
-        Preconditions.checkTrue(StringUtils.isNotBlank(this.name), "process name cannot be empty");
-        Preconditions.checkTrue(StringUtils.isNotBlank(this.displayName), "process display name cannot be empty");
+        Preconditions.expectTrue(StringUtils.isNotBlank(this.name), "process name cannot be empty");
+        Preconditions.expectTrue(StringUtils.isNotBlank(this.displayName), "process display name cannot be empty");
     }
 
     @Override
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/NextableElement.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/NextableElement.java
index 34d9388e4..5e1b414d4 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/NextableElement.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/NextableElement.java
@@ -51,7 +51,7 @@ public abstract class NextableElement extends Element {
     }
 
     public NextableElement addNext(WorkflowAction action, Predicate<WorkflowContext> condition, Element next) {
-        Preconditions.checkTrue(supportedActions().contains(action),
+        Preconditions.expectTrue(supportedActions().contains(action),
                 "not support workflow action " + action + ", it should in one of " + supportedActions());
         actionToNextElementMap.computeIfAbsent(action, ac -> Lists.newArrayList())
                 .add(new ConditionNextElement().setCondition(condition).setElement(next));
@@ -63,7 +63,7 @@ public abstract class NextableElement extends Element {
     }
 
     public List<Element> getNextList(WorkflowAction action, WorkflowContext context) {
-        Preconditions.checkTrue(supportedActions().contains(action),
+        Preconditions.expectTrue(supportedActions().contains(action),
                 "not support workflow action " + action + ", it should in one of " + supportedActions());
         return this.actionToNextElementMap.getOrDefault(action, NextableElement.EMPTY_NEXT)
                 .stream()
@@ -78,7 +78,7 @@ public abstract class NextableElement extends Element {
 
     @Override
     public void validate() {
-        Preconditions.checkNotEmpty(actionToNextElementMap,
+        Preconditions.expectNotEmpty(actionToNextElementMap,
                 "next elements cannot be null " + this.getClass().getName());
     }
 
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/ServiceTask.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/ServiceTask.java
index 8b784fa30..e859cae90 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/ServiceTask.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/ServiceTask.java
@@ -62,7 +62,7 @@ public class ServiceTask extends WorkflowTask {
 
     @Override
     public List<Element> getNextList(WorkflowAction action, WorkflowContext context) {
-        Preconditions.checkTrue(supportedActions().contains(action),
+        Preconditions.expectTrue(supportedActions().contains(action),
                 "not support workflow action " + action + ", it in one of " + supportedActions());
         switch (action) {
             case COMPLETE:
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/UserTask.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/UserTask.java
index 4bb6aee1e..6a3e28002 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/UserTask.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/UserTask.java
@@ -58,7 +58,7 @@ public class UserTask extends WorkflowTask {
 
     @Override
     public List<Element> getNextList(WorkflowAction action, WorkflowContext context) {
-        Preconditions.checkTrue(supportedActions().contains(action),
+        Preconditions.expectTrue(supportedActions().contains(action),
                 "not support workflow action " + action + ", it should in one of " + supportedActions());
         switch (action) {
             case APPROVE:
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/WorkflowProcess.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/WorkflowProcess.java
index 3a6a532cc..82e3baa3e 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/WorkflowProcess.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/definition/WorkflowProcess.java
@@ -124,9 +124,9 @@ public class WorkflowProcess extends Element {
     @Override
     public void validate() {
         super.validate();
-        Preconditions.checkNotEmpty(type, "process type cannot be empty");
-        Preconditions.checkNotNull(startEvent, "start event cannot be null");
-        Preconditions.checkNotNull(endEvent, "end event cannot be null");
+        Preconditions.expectNotEmpty(type, "process type cannot be empty");
+        Preconditions.expectNotNull(startEvent, "start event cannot be null");
+        Preconditions.expectNotNull(endEvent, "end event cannot be null");
 
         startEvent.validate();
         endEvent.validate();
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/AbstractNextableElementProcessor.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/AbstractNextableElementProcessor.java
index ebfd091fc..cf23bddd8 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/AbstractNextableElementProcessor.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/AbstractNextableElementProcessor.java
@@ -38,7 +38,7 @@ public abstract class AbstractNextableElementProcessor<T extends NextableElement
     public List<Element> next(T element, WorkflowContext context) {
         WorkflowContext.ActionContext actionContext = context.getActionContext();
         List<Element> nextElements = element.getNextList(actionContext.getAction(), context);
-        Preconditions.checkNotEmpty(nextElements, "not found next element ");
+        Preconditions.expectNotEmpty(nextElements, "not found next element ");
 
         Element endEvent = nextElements
                 .stream()
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/ServiceTaskProcessor.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/ServiceTaskProcessor.java
index d974ac0f2..406c98a3a 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/ServiceTaskProcessor.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/ServiceTaskProcessor.java
@@ -107,7 +107,7 @@ public class ServiceTaskProcessor extends AbstractTaskProcessor<ServiceTask> {
             actionContext = context.getActionContext();
         }
         WorkflowTaskEntity taskEntity = actionContext.getTaskEntity();
-        Preconditions.checkTrue(ALLOW_COMPLETE_STATE.contains(TaskStatus.valueOf(taskEntity.getStatus())),
+        Preconditions.expectTrue(ALLOW_COMPLETE_STATE.contains(TaskStatus.valueOf(taskEntity.getStatus())),
                 String.format("task status %s not allowed to complete", taskEntity.getStatus()));
 
         try {
@@ -172,7 +172,7 @@ public class ServiceTaskProcessor extends AbstractTaskProcessor<ServiceTask> {
         taskEntity.setStartTime(new Date());
 
         taskEntityMapper.insert(taskEntity);
-        Preconditions.checkNotNull(taskEntity.getId(), "task saved failed");
+        Preconditions.expectNotNull(taskEntity.getId(), "task saved failed");
         return taskEntity;
     }
 
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/StartEventProcessor.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/StartEventProcessor.java
index 2b98103a8..829e5d8e6 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/StartEventProcessor.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/StartEventProcessor.java
@@ -60,8 +60,8 @@ public class StartEventProcessor extends AbstractNextableElementProcessor<StartE
         WorkflowProcess process = context.getProcess();
         ProcessForm form = context.getProcessForm();
         if (process.getFormClass() != null) {
-            Preconditions.checkNotNull(form, "process form cannot be null");
-            Preconditions.checkTrue(form.getClass().isAssignableFrom(process.getFormClass()),
+            Preconditions.expectNotNull(form, "process form cannot be null");
+            Preconditions.expectTrue(form.getClass().isAssignableFrom(process.getFormClass()),
                     String.format("form type %s should match the process form type %s",
                             form.getClass(), process.getFormClass()));
             form.validate();
@@ -107,7 +107,7 @@ public class StartEventProcessor extends AbstractNextableElementProcessor<StartE
         processEntity.setHidden(process.getHidden());
 
         processEntityMapper.insert(processEntity);
-        Preconditions.checkNotNull(processEntity.getId(), "process saved failed");
+        Preconditions.expectNotNull(processEntity.getId(), "process saved failed");
         return processEntity;
     }
 }
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/UserTaskProcessor.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/UserTaskProcessor.java
index f01812641..b2f8c01f5 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/UserTaskProcessor.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/processor/UserTaskProcessor.java
@@ -77,7 +77,7 @@ public class UserTaskProcessor extends AbstractTaskProcessor<UserTask> {
     @Override
     public boolean create(UserTask userTask, WorkflowContext context) {
         List<String> approvers = userTask.getApproverAssign().assign(context);
-        Preconditions.checkNotEmpty(approvers, "Cannot assign approvers for task: " + userTask.getDisplayName()
+        Preconditions.expectNotEmpty(approvers, "Cannot assign approvers for task: " + userTask.getDisplayName()
                 + ", as the approvers was empty");
 
         if (!userTask.isNeedAllApprove()) {
@@ -103,11 +103,11 @@ public class UserTaskProcessor extends AbstractTaskProcessor<UserTask> {
     @Override
     public boolean complete(WorkflowContext context) {
         WorkflowContext.ActionContext actionContext = context.getActionContext();
-        Preconditions.checkTrue(SUPPORT_ACTIONS.contains(actionContext.getAction()),
+        Preconditions.expectTrue(SUPPORT_ACTIONS.contains(actionContext.getAction()),
                 "UserTask not support action:" + actionContext.getAction());
 
         WorkflowTaskEntity workflowTaskEntity = actionContext.getTaskEntity();
-        Preconditions.checkTrue(TaskStatus.PENDING.name().equalsIgnoreCase(workflowTaskEntity.getStatus()),
+        Preconditions.expectTrue(TaskStatus.PENDING.name().equalsIgnoreCase(workflowTaskEntity.getStatus()),
                 "task status should be pending");
 
         checkOperator(actionContext);
@@ -156,7 +156,7 @@ public class UserTaskProcessor extends AbstractTaskProcessor<UserTask> {
         taskEntity.setStartTime(new Date());
 
         taskEntityMapper.insert(taskEntity);
-        Preconditions.checkNotNull(taskEntity.getId(), "task saved failed");
+        Preconditions.expectNotNull(taskEntity.getId(), "task saved failed");
         return taskEntity;
     }
 
@@ -189,13 +189,13 @@ public class UserTaskProcessor extends AbstractTaskProcessor<UserTask> {
         try {
             TaskForm taskForm = actionContext.getForm();
             if (needForm(userTask, actionContext.getAction())) {
-                Preconditions.checkNotNull(taskForm, "form cannot be null");
-                Preconditions.checkTrue(taskForm.getClass().isAssignableFrom(userTask.getFormClass()),
+                Preconditions.expectNotNull(taskForm, "form cannot be null");
+                Preconditions.expectTrue(taskForm.getClass().isAssignableFrom(userTask.getFormClass()),
                         "form type not match, should be class " + userTask.getFormClass());
                 taskForm.validate();
                 taskEntity.setFormData(objectMapper.writeValueAsString(taskForm));
             } else {
-                Preconditions.checkNull(taskForm, "no form required");
+                Preconditions.expectNull(taskForm, "no form required");
             }
             taskEntity.setEndTime(new Date());
 
diff --git a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/util/WorkflowUtils.java b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/util/WorkflowUtils.java
index 026f1a937..d9ae13c80 100644
--- a/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/util/WorkflowUtils.java
+++ b/inlong-manager/manager-workflow/src/main/java/org/apache/inlong/manager/workflow/util/WorkflowUtils.java
@@ -168,7 +168,7 @@ public class WorkflowUtils {
      */
     public static <T extends ProcessForm> T parseProcessForm(ObjectMapper objectMapper, String form,
             WorkflowProcess process) {
-        Preconditions.checkNotNull(process, "process cannot be null");
+        Preconditions.expectNotNull(process, "process cannot be null");
         if (StringUtils.isEmpty(form)) {
             return null;
         }
@@ -187,15 +187,15 @@ public class WorkflowUtils {
      */
     public static <T extends TaskForm> T parseTaskForm(ObjectMapper objectMapper, WorkflowTaskEntity taskEntity,
             WorkflowProcess process) {
-        Preconditions.checkNotNull(taskEntity, "taskEntity cannot be null");
-        Preconditions.checkNotNull(process, "process cannot be null");
+        Preconditions.expectNotNull(taskEntity, "taskEntity cannot be null");
+        Preconditions.expectNotNull(process, "process cannot be null");
         if (StringUtils.isEmpty(taskEntity.getFormData())) {
             return null;
         }
 
         WorkflowTask task = process.getTaskByName(taskEntity.getName());
-        Preconditions.checkNotNull(task, "user task not exist " + taskEntity.getName());
-        Preconditions.checkTrue(task instanceof UserTask, "task should be userTask " + taskEntity.getName());
+        Preconditions.expectNotNull(task, "user task not exist " + taskEntity.getName());
+        Preconditions.expectTrue(task instanceof UserTask, "task should be userTask " + taskEntity.getName());
 
         UserTask userTask = (UserTask) task;
         try {