diff --git a/.run/CMII镜像同步-11.8-ARM.run.xml b/.run/CMII镜像同步-11.8-ARM.run.xml
new file mode 100644
index 0000000..51e5a7f
--- /dev/null
+++ b/.run/CMII镜像同步-11.8-ARM.run.xml
@@ -0,0 +1,15 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/.run/Cmii镜像同步-35.70.run.xml b/.run/Cmii镜像同步-35.70.run.xml
new file mode 100644
index 0000000..543cddb
--- /dev/null
+++ b/.run/Cmii镜像同步-35.70.run.xml
@@ -0,0 +1,15 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/.run/DEMO更新-3570.run.xml b/.run/DEMO更新-3570.run.xml
index 97892c6..39cd61f 100644
--- a/.run/DEMO更新-3570.run.xml
+++ b/.run/DEMO更新-3570.run.xml
@@ -1,15 +1,15 @@
-
-
-
-
-
-
-
-
-
-
-
-
-
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/.run/Middle镜像-35.70.run.xml b/.run/Middle镜像-35.70.run.xml
new file mode 100644
index 0000000..d5389f9
--- /dev/null
+++ b/.run/Middle镜像-35.70.run.xml
@@ -0,0 +1,15 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/.run/Middle镜像-ARM-11.8.run.xml b/.run/Middle镜像-ARM-11.8.run.xml
new file mode 100644
index 0000000..3c20599
--- /dev/null
+++ b/.run/Middle镜像-ARM-11.8.run.xml
@@ -0,0 +1,15 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/.run/院内镜像清理-35.70.run.xml b/.run/院内Harbor清理-35.70.run.xml
similarity index 89%
rename from .run/院内镜像清理-35.70.run.xml
rename to .run/院内Harbor清理-35.70.run.xml
index 8377947..04bbf5d 100644
--- a/.run/院内镜像清理-35.70.run.xml
+++ b/.run/院内Harbor清理-35.70.run.xml
@@ -1,5 +1,5 @@
-
+
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/Dev_Fusion.py b/agent-common/SplitProject/ranjing-python-devfusion/Dev_Fusion.py
new file mode 100644
index 0000000..d68a68e
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/Dev_Fusion.py
@@ -0,0 +1,387 @@
+import random
+import threading
+from queue import Queue
+from paho.mqtt import client as mqtt_client
+import numpy as np
+import time
+import logging
+import os
+import datetime
+from KF_V2 import *
+from utils import *
+from config import *
+import argparse
+import json
+import yaml
+
+# 首先加载yaml配置
+def load_mqtt_config():
+ config_path = os.getenv('CONFIG_PATH', 'config.yaml')
+ with open(config_path, 'r') as f:
+ config = yaml.safe_load(f)
+ return config['mqtt'], config['topics']
+
+# 获取MQTT和topics配置
+mqtt_config, topics_config = load_mqtt_config()
+
+## =======================
+# MQTT 代理地址
+# broker = '192.168.36.234'
+# port = 37826
+# username = "cmlc"
+# password = "odD8#Ve7.B"
+client_id = f'python-mqtt-{random.randint(0, 100)}'
+
+ # 创建 ArgumentParser 对象
+parser = argparse.ArgumentParser(description='处理命令行参数')
+
+# 添加参数 task_id,简称 t,类型为 int,默认值为 1
+parser.add_argument('-t', '--task_id', type=str, default="+", help='任务ID')
+
+# 添加参数 gate,简称 g,类型为 str,默认值为 "default_gate"
+parser.add_argument('-g', '--gate', type=int, default=30, help='门限值')
+
+# 添加参数 interval,简称 i,类型为 float,默认值为 1.0
+parser.add_argument('-i', '--interval', type=float, default=1.0, help='时间间隔')
+
+# 解析命令行参数
+args = parser.parse_args()
+
+# 实例化 DataFusion 类
+fusion_instance = DataFusion(
+
+ gate=args.gate,
+ interval=args.interval,
+
+
+
+)
+
+global task_id
+task_id = "10087"
+
+# 从yaml的mqtt_topic中提取基础路径
+base_path = topics_config['mqtt_topic'].split('/')[0] # 获取"bridge"
+
+# 更新数据上报的主题格式
+providerCode = "DP74b4ef9fb4aaf269"
+fusionCode = "DPZYLY"
+deviceType = "5ga"
+fusionType = "fusion"
+deviceId = "10580005"
+fusionId = "554343465692430336"
+sensor_id_list = ["80103"]
+
+# 使用base_path构建topic
+topic = f"{base_path}/{providerCode}/device_data/{deviceType}/{deviceId}"
+
+# 从yaml的sensor_topic中提取基础路径
+base_topic = topics_config['sensor_topic'].split('FU_PAM')[0] # 得到 "fromcheck/DP74b4ef9fb4aaf269/device_data/"
+
+# 订阅主题 - 基于yaml格式构建
+subscribe_topic = f"{base_topic}5ga/10000000000000" # 将FU_PAM替换为5ga,将+替换为具体ID
+
+# 发布融合结果的主题
+# fusionId的来源是下发任务时的ID
+publish_topic = f"fromcheck/{fusionCode}/device_data/{fusionType}/{task_id}"
+# 更新运行参数的主题
+fusion_parameters_topic = topics_config['sensor_topic']
+# 生成唯一的 client_id
+
+# 数据池
+data_pool = Queue()
+run_parameter = None
+interval = args.interval
+
+# 定义参考点 PO(纬度, 经度)
+global reference_point
+reference_point = (104.08, 30.51) # 参考点的经纬度
+# 数据池
+data_pool = Queue()
+run_parameter = None
+# 初始化数据处理类
+pipe = Pipeline(fusion_parameters_topic=topics_config['sensor_topic'], reference_point=reference_point)
+
+fusion_code = "FU_PAM/"+args.task_id
+
+# 设置日志记录
+def setup_logging():
+ # 创建logs目录(如果不存在)
+ if not os.path.exists('logs'):
+ os.makedirs('logs')
+
+ # 设置日志文件名(包含日期)
+ current_time = datetime.datetime.now()
+ error_log_filename = f'logs/mqtt_connection_{current_time.strftime("%Y%m%d")}_error.log'
+
+ # 配置总的日志记录器
+ logging.basicConfig(
+ level=logging.INFO, # 记录所有信息
+ format='%(asctime)s - %(levelname)s - %(message)s',
+ handlers=[
+ logging.StreamHandler() # 同时输出到控制台
+ ]
+ )
+
+ # 配置错误日志记录器
+ error_logger = logging.getLogger('error_logger')
+ error_logger.setLevel(logging.ERROR)
+
+ # 创建文件处理器
+ error_handler = logging.FileHandler(error_log_filename)
+ error_handler.setFormatter(logging.Formatter('%(asctime)s - %(levelname)s - %(message)s'))
+
+ # 添加处理器到错误日志记录器
+ error_logger.addHandler(error_handler)
+
+def connect_mqtt() -> mqtt_client:
+ def on_connect(client, userdata, flags, rc):
+ if rc == 0:
+ logging.info("Successfully connected to MQTT Broker")
+ logging.info(f"Client ID: {client_id}")
+ logging.info(f"Broker: {mqtt_config['broker']}:{mqtt_config['port']}")
+ # 重新订阅主题
+ client.subscribe(fusion_parameters_topic)
+ logging.info(f"Subscribed to fusion parameters topic: {fusion_parameters_topic}")
+ if hasattr(pipe, 'topics'):
+ for topic in pipe.topics:
+ client.subscribe(topic)
+ logging.info(f"Subscribed to topic: {topic}")
+ else:
+ logging.error(f"Failed to connect, return code: {rc} ({DISCONNECT_REASONS.get(rc, '未知错误')})")
+
+ def on_disconnect(client, userdata, rc):
+ current_time = datetime.datetime.now()
+ reason = DISCONNECT_REASONS.get(rc, "未知错误")
+
+ logging.warning(f"Disconnected from MQTT Broker at {current_time.strftime('%Y-%m-%d %H:%M:%S')}")
+ logging.warning(f"Disconnect reason code: {rc} - {reason}")
+
+ if rc != 0:
+ logging.error("Unexpected disconnection. Attempting to reconnect...")
+ try:
+ client.reconnect()
+ logging.info("Reconnection successful")
+ except Exception as e:
+ current_time = datetime.datetime.now()
+ logging.error(f"Reconnection failed at {current_time.strftime('%Y-%m-%d %H:%M:%S')}: {str(e)}")
+ logging.error(f"Exception type: {type(e).__name__}")
+ logging.error(f"Stack trace:", exc_info=True)
+
+ client = mqtt_client.Client(client_id, clean_session=True)
+ client.username_pw_set(mqtt_config['username'], mqtt_config['password'])
+
+ # 设置保活时间和重试间隔
+ client.keepalive = 60 # 60秒的保活时间
+ client.socket_timeout = 30 # 30秒的socket超时
+ client.reconnect_delay_set(min_delay=1, max_delay=60) # 重连延迟在1-60秒之间
+
+ # 设置遗嘱消息(last will message)
+ will_topic = f"fromcheck/{fusionCode}/status/{task_id}"
+ will_payload = "offline"
+ client.will_set(will_topic, will_payload, qos=1, retain=True)
+
+ # 设置回调函数
+ client.on_connect = on_connect
+ client.on_disconnect = on_disconnect
+
+ try:
+ client.connect(mqtt_config['broker'], mqtt_config['port'])
+ except Exception as e:
+ logging.error(f"Initial connection failed: {str(e)}")
+ logging.error(f"Exception type: {type(e).__name__}")
+ logging.error(f"Stack trace:", exc_info=True)
+ time.sleep(5)
+ return connect_mqtt()
+
+ # 发送上线状态
+ client.publish(will_topic, "online", qos=1, retain=True)
+
+ return client
+
+def subscribe(client: mqtt_client):
+ def on_message(client, userdata, msg):
+ try:
+ global run_parameter
+ global task_id
+ logging.info(f"Received message on topic: {msg.topic}")
+ logging.info(f"Message payload: {msg.payload.decode()}")
+
+ if "FU_PAM" in msg.topic:
+ if args.task_id == '+' or fusion_code in msg.topic:
+ new_run_parameter = msg.payload.decode()
+ if run_parameter != new_run_parameter:
+ logging.info(f"Run parameter updated from {run_parameter} to {new_run_parameter}")
+ run_parameter = new_run_parameter
+ new_topics = pipe.extract_parms(run_parameter)
+ logging.info(f"Extracted topics: {new_topics}")
+ client.subscribe(new_topics) # 重新更新订阅的数据
+ logging.info(f"Subscribed to new topics: {new_topics}")
+ logging.info('===========new run_parameter!===============')
+ current_time = datetime.datetime.now()
+ task_id = pipe.task_id
+ else:
+ data_pool.put((msg.topic, msg.payload))
+ except Exception as e:
+ logging.error(f"Error processing message: {str(e)}")
+ logging.error(f"Exception type: {type(e).__name__}")
+ logging.error(f"Stack trace:", exc_info=True)
+
+ subscribe_topics = [(subscribe_topic, 0), (fusion_parameters_topic, 0)] # 默认QoS为0
+ client.subscribe(subscribe_topics)
+ client.on_message = on_message
+
+
+def publish(client, message):
+ global task_id
+ global fusionCode
+ max_retries = 3
+ retry_delay = 1 # 初始重试延迟(秒)
+
+ def do_publish():
+ publish_topic = f"bridge/{fusionCode}/device_data/fusion/{task_id}"
+ try:
+ result = client.publish(publish_topic, message)
+ status = result.rc
+ if status == 0:
+ current_time = datetime.datetime.now()
+ formatted_time = current_time.strftime('%Y-%m-%d %H:%M:%S')
+ with open('log.txt', 'a') as log_file:
+ log_file.write('=====================\n')
+ log_file.write(f"Send message to topic {publish_topic}\n")
+ log_file.write(f"time: {formatted_time}\n")
+ log_file.write(f"{message}\n")
+ return True
+ else:
+ logging.error(f"Failed to send message to topic {publish_topic}, status: {status}")
+ return False
+ except Exception as e:
+ logging.error(f"Error publishing message: {str(e)}")
+ logging.error(f"Exception type: {type(e).__name__}")
+ logging.error(f"Stack trace:", exc_info=True)
+ return False
+
+ # 实现重试逻辑
+ for attempt in range(max_retries):
+ if do_publish():
+ return
+ if attempt < max_retries - 1: # 如果不是最后一次尝试
+ retry_delay *= 2 # 指数退避
+ logging.warning(f"Retrying publish in {retry_delay} seconds...")
+ time.sleep(retry_delay)
+
+ logging.error(f"Failed to publish message after {max_retries} attempts")
+
+
+def data_fusion(fusion_container):
+ global data_pool
+ data_list = []
+ # 从数据池中提取所有的数据
+ while not data_pool.empty():
+ data_now = data_pool.get()
+ processed_data = pipe.process_json_data(data_now[1])
+
+ # 筛选有意义的数据
+ if processed_data and processed_data.get("objects"): # 只记录有 objects 的数据
+ data_list.append(processed_data)
+
+ if data_list: # 只有当有数据时才写日志
+ current_time = datetime.datetime.now()
+ formatted_time = current_time.strftime('%Y-%m-%d %H:%M:%S')
+ with open('Data_log.txt', 'a') as log_file: # 以追加模式打开日志文件
+ log_file.write('=====================\n') # 写入分隔符
+ log_file.write(f"Get message \n")
+ log_file.write(f"time: {formatted_time}\n") # 写入分隔符
+ log_file.write(f"{data_list}\n") # 写入消息内容
+
+ sensor_data = pipe.data_encoder(data_list)
+ logging.info(sensor_data)
+ filtered_results = fusion_container.run(sensor_data)
+ processed_data = pipe.data_decoder(filtered_results)
+ processed_data = json.dumps(processed_data, indent=4)
+ return processed_data # 返回处理后的 JSON 字符串
+
+
+def fusion_runner(client):
+ global run_parameter
+ pre_run_parameter = run_parameter
+ last_run_time = time.time()
+ last_health_check = time.time()
+ health_check_interval = 30 # 每30秒进行一次健康检查
+ fusion_container = DataFusion(args.gate, args.interval)
+
+
+ def check_connection():
+ if not client.is_connected():
+ logging.warning("MQTT client disconnected during fusion_runner")
+ try:
+ client.reconnect()
+ logging.info("Successfully reconnected in fusion_runner")
+ return True
+ except Exception as e:
+ logging.error(f"Reconnection failed in fusion_runner: {str(e)}")
+ logging.error(f"Exception type: {type(e).__name__}")
+ logging.error(f"Stack trace:", exc_info=True)
+ return False
+ return True
+
+ while True:
+ try:
+ current_time = time.time()
+
+ # 定期健康检查
+ if current_time - last_health_check >= health_check_interval:
+ if not check_connection():
+ time.sleep(5) # 如果连接失败,等待5秒后继续
+ continue
+ last_health_check = current_time
+
+ # 数据处理和发送
+ if current_time - last_run_time >= interval:
+ if not check_connection():
+ continue
+
+ last_run_time = current_time
+
+ if run_parameter != pre_run_parameter:
+ fusion_parms = pipe.extract_fusion_parms(run_parameter)
+ fusion_container.set_parameter(fusion_parms)
+ pre_run_parameter= run_parameter
+
+
+ processed_data = data_fusion(fusion_container)
+ if processed_data:
+ publish(client, processed_data)
+
+ except Exception as e:
+ logging.error(f"Error in fusion_runner: {str(e)}")
+ logging.error(f"Exception type: {type(e).__name__}")
+ logging.error(f"Stack trace:", exc_info=True)
+ time.sleep(1)
+
+def run():
+ # 初始化日志系统
+ setup_logging()
+ logging.error("Starting MQTT client application")
+
+ while True: # 添加外层循环来处理完全断开的情况
+ try:
+ client = connect_mqtt()
+ subscribe(client)
+
+ logging.info("Starting fusion_runner thread")
+ fusion_runner_thread = threading.Thread(target=fusion_runner, args=(client,), daemon=True)
+ fusion_runner_thread.start()
+
+ logging.info("Starting MQTT loop")
+ client.loop_forever()
+ except Exception as e:
+ logging.critical(f"Critical error in main loop: {str(e)}")
+ logging.critical(f"Exception type: {type(e).__name__}")
+ logging.critical(f"Stack trace:", exc_info=True)
+ logging.info("Restarting in 5 seconds...")
+ time.sleep(5)
+
+
+if __name__ == '__main__':
+ run()
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/Dev_Publish.py b/agent-common/SplitProject/ranjing-python-devfusion/Dev_Publish.py
new file mode 100644
index 0000000..eb98372
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/Dev_Publish.py
@@ -0,0 +1,145 @@
+import json
+import time
+import random
+from math import radians, degrees, sin, cos
+from paho.mqtt import client as mqtt_client
+import datetime
+import numpy as np
+from math import atan2, sqrt
+
+
+# 坐标转换函数
+def convert_to_cartesian(lat, lon, reference_point):
+ """将经纬度转换为基于参考点的直角坐标,考虑地球椭球模型"""
+ # 地球椭球参数(WGS84)
+ a = 6378137.0 # 长半轴,单位:米
+ f = 1 / 298.257223563 # 扁率
+ e2 = 2 * f - f ** 2 # 第一偏心率平方
+
+ # 提取参考点坐标
+ ref_lat, ref_lon = reference_point
+
+ # 转换成弧度
+ lat_rad = radians(lat)
+ lon_rad = radians(lon)
+ ref_lat_rad = radians(ref_lat)
+ ref_lon_rad = radians(ref_lon)
+
+ # 计算曲率半径
+ N = a / sqrt(1 - e2 * sin(ref_lat_rad) ** 2) # 参考点处的卯酉圈曲率半径
+
+ # 计算基于参考点的平面直角坐标
+ delta_lon = lon_rad - ref_lon_rad
+ X = (N + 0) * cos(ref_lat_rad) * delta_lon
+ Y = (a * (1 - e2)) / (1 - e2 * sin(ref_lat_rad) ** 2) * (lat_rad - ref_lat_rad)
+
+ return X, Y
+
+
+# 模拟数据生成函数
+def generate_simulated_data(reference_point, radius_km, angle):
+ """生成模拟数据,符合 Pipeline 处理需求"""
+ R = 6371000 # 地球半径(米)
+
+ # 将半径转换为弧度
+ radius = radius_km / R
+
+ # 计算参考点经纬度
+ lat0, lon0 = reference_point
+
+ # 计算新的点的经度和纬度
+ new_lat = lat0 + degrees(radius * cos(radians(angle)))
+ new_lon = lon0 + degrees(radius * sin(radians(angle)) / cos(radians(lat0)))
+
+ # 生成模拟 JSON 数据
+ mock_data = {
+ "deviceId": "80103",
+ "deviceType": 10,
+ "objects": [
+ {
+ "altitude": 150.0, # 模拟高度
+ "extension": {
+ "traceId": "00000000000001876",
+ "channel": "5756500000",
+ "objectType": 30,
+ "uavId": "UAS123456", # 新增字段,与 Pipeline 对应
+ "uavModel": "DJI Mini 3 Pro", # 模拟 UAV 型号
+ "deviceId": "80103" # 来源设备 ID
+ },
+ "height": 120.0, # 高度
+ "latitude": new_lat,
+ "longitude": new_lon,
+ "X": 0.0, # 预留字段,供转换函数填充
+ "Y": 0.0, # 预留字段,供转换函数填充
+ "speed": 15.0, # 模拟速度
+ "objectId": "AX0009", # 模拟目标 ID
+ "time": int(time.time() * 1000), # 当前时间戳(毫秒)
+ "source": [["sensor1", "UAS123456"]] # 模拟来源
+ }
+ ],
+ "providerCode": "ZYLYTEST",
+ "ptTime": int(time.time() * 1000) # 当前时间戳(毫秒)
+ }
+
+ # 转换坐标
+ for obj in mock_data["objects"]:
+ lat, lon = obj["latitude"], obj["longitude"]
+ obj["X"], obj["Y"] = convert_to_cartesian(lat, lon, reference_point)
+
+ return json.dumps(mock_data, indent=4)
+
+
+# MQTT 推送代码
+broker = '192.168.36.234'
+port = 37826
+providerCode = "DP74b4ef9fb4aaf269"
+deviceType = "5ga"
+deviceId = "10580015"
+topic = f"bridge/{providerCode}/device_data/{deviceType}/{deviceId}"
+client_id = f'python-mqtt-{random.randint(0, 1000)}'
+username = "cmlc"
+password = "odD8#Ve7.B"
+reference_point = (31.880000, 117.240000) # 经度和纬度
+radius = 1500 # 半径,单位:米
+
+
+def connect_mqtt():
+ """连接 MQTT Broker"""
+ def on_connect(client, userdata, flags, rc):
+ if rc == 0:
+ print("Connected to MQTT Broker!")
+ else:
+ print(f"Failed to connect, return code {rc}")
+
+ client = mqtt_client.Client(client_id)
+ client.on_connect = on_connect
+ client.username_pw_set(username, password)
+ client.connect(broker, port)
+ return client
+
+
+def publish(client):
+ """推送生成的模拟数据"""
+ msg_count = 0
+ angle = 0
+ while True:
+ time.sleep(1)
+ msg = generate_simulated_data(reference_point, radius, angle)
+ result = client.publish(topic, msg)
+ status = result.rc
+ if status == 0:
+ print(f"Send `{msg_count}` to topic `{topic}`")
+ else:
+ print(f"Failed to send message to topic {topic}")
+ msg_count += 1
+ angle += 1
+
+
+def run():
+ client = connect_mqtt()
+ client.loop_start()
+ publish(client)
+
+
+if __name__ == '__main__':
+ run()
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/Dockerfile b/agent-common/SplitProject/ranjing-python-devfusion/Dockerfile
new file mode 100644
index 0000000..72f5be5
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/Dockerfile
@@ -0,0 +1,15 @@
+# 构建阶段
+FROM python:3.12.8-slim-bookworm as builder
+
+WORKDIR /build
+COPY requirements.txt .
+RUN pip install --user -r requirements.txt -i https://pypi.tuna.tsinghua.edu.cn/simple
+
+# 运行阶段
+FROM python:3.12.8-slim-bookworm
+
+WORKDIR /app
+COPY --from=builder /root/.local/lib/python3.12/site-packages /root/.local/lib/python3.12/site-packages
+COPY . .
+
+CMD ["python", "check.py"]
\ No newline at end of file
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/KF_V2.py b/agent-common/SplitProject/ranjing-python-devfusion/KF_V2.py
new file mode 100644
index 0000000..1046438
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/KF_V2.py
@@ -0,0 +1,279 @@
+import datetime
+from os import error
+import numpy as np
+from config import *
+
+def calculate_euclidean_distances(A, B):
+ # 计算A和B之间的欧式距离
+ distances = np.linalg.norm(A - B, axis=1)
+ # 找到最小距离及其索引
+ min_distance_index = np.argmin(distances)
+ min_distance = distances[min_distance_index]
+ return min_distance, min_distance_index
+
+def are_lists_equal(listA, listB):
+ # 对两个列表中的子列表进行排序
+ if len(listA) == 0:
+ return False
+ sorted_listA = sorted(listA, key=lambda x: (x[0], x[1]))
+ sorted_listB = sorted(listB, key=lambda x: (x[0], x[1]))
+ # 比较排序后的列表是否相等
+ return sorted_listA == sorted_listB
+
+def sigmoid(x, a=10, b=0.1):
+ # 调整Sigmoid函数使其在x=1时值为0.5
+ # a和b是调整参数,用于控制函数的形状
+ return 1 / (1 + np.exp(-a * (x - shift_value))) + b
+
+
+class KalmanFilter:
+ def __init__(self, measurement, com_id, measurement_variance=1,process_variance=1e-1):
+ current_time = datetime.datetime.now()
+ timestamp = int(current_time.timestamp() * 1000000)
+ ms = measurement.tolist()
+ self.m = np.array([ms[0],ms[1],ms[2],0,0,0]) # 状态量,6维度
+ self.origin = [com_id] #origin 表示最强响应
+ self.source = self.origin #source 表示所有关联的观测值
+ self.survive = np.array(survive_initial) # 初始化生存值
+ self.duration = 0
+ self.counter = 0
+ self.id = str(timestamp % 3600000000 + np.random.randint(1000))
+ self.F = [[1,0,0,1,0,0],
+ [0,1,0,0,1,0],
+ [0,0,1,0,0,1],
+ [0,0,0,1,0,0],
+ [0,0,0,0,1,0],
+ [0,0,0,0,0,1]]
+ self.F = np.array(self.F)
+ self.H = [[1,0,0,0,0,0],
+ [0,1,0,0,0,0],
+ [0,0,1,0,0,0]]
+ self.H = np.array(self.H)
+ self.R = measurement_variance * np.eye(3)
+ self.Q = process_variance * np.eye(6)
+ self.Q[3, 3] = self.Q[3, 3] * 1e-3
+ self.Q[4, 4] = self.Q[4, 4] * 1e-3
+ self.Q[5, 5] = self.Q[5, 5] * 1e-3
+ self.P = np.eye(6)*0.1
+ self.I = np.eye(6)
+ self.expend = 1
+ self.v = np.array([0,0,0])
+ self.born_time = int(current_time.timestamp() * 1000)
+ self.latest_update = self.born_time
+
+ self.m_history = self.m
+ self.s_history = []
+ self.origin_set = [self.origin]
+
+
+ def predict(self):
+ F = self.F
+ self.m = np.dot(F,self.m.T) # 简单一步预测模型
+ self.m = self.m.T
+ self.P = np.dot(np.dot(F,self.P),F.T) + self.Q
+ self.survive = self.survive * decay # 应用衰减值
+ self.origin_set = np.unique(np.array(self.origin_set), axis=0).tolist() # 计算关联集合
+
+ def update(self, res, run_timestamp, gate):
+ self.duration += 0.6 # 每次更新时,持续时间+0.6
+ if len(res['distances']) == 0:
+ mmd = 1e8
+ else:
+ min_distance_index = np.argmin(res['distances'])
+ mmd = res['distances'][min_distance_index]
+ measurement = res['measurements'][min_distance_index]
+
+ # 进行更新
+ if mmd < gate * self.expend:
+ H = self.H
+ I = self.I
+ self.expend = max(self.expend * 0.8, 1)
+ kalman_gain = np.dot(np.dot(self.P,H.T),np.linalg.pinv(np.dot(np.dot(H,self.P),H.T)+self.R))
+ self.m += np.dot(kalman_gain,(measurement.T - np.dot(H,self.m.T)))
+ self.m = self.m.T
+ self.P = np.dot((I - np.dot(kalman_gain,H)),self.P)
+ self.origin = [res['key_ids'][min_distance_index]]
+ self.counter += 1
+ self.survive = sigmoid(self.counter) # 新映射函数
+ # 如下操作防止对速度过于自信
+ self.P[3, 3] = max(1e-1, self.P[3, 3])
+ self.P[4, 4] = max(1e-1, self.P[4, 4])
+ self.P[5, 5] = max(1e-1, self.P[5, 5])
+ # 截取速度
+ self.v = self.m[3:6]
+ self.origin_set.append(self.origin)
+ self.latest_update = run_timestamp #对时间进行处理
+ else:
+ self.expend = min(self.expend*1.2,1.5) # 若关联不上,则扩大门限继续搜索
+ self.P[3, 3] = min(self.P[3, 3]*1.1,1)
+ self.P[4, 4] = min(self.P[4, 4]*1.1,1)
+ self.P[5, 5] = min(self.P[5, 5]*1.1,1)
+ self.counter -= 1
+ self.counter = max(self.counter,0)
+
+ self.m_history = np.vstack((self.m_history, self.m))
+ self.s_history.append(self.survive)
+
+ def one_correlation(self, data_matrix, id_list):
+ # 计算现有数据与data_matrix的差距
+ min_distance, min_index = calculate_euclidean_distances(self.m[0:3], data_matrix)
+ m_id = id_list[min_index]
+ measurement = data_matrix[min_index, :]
+ return m_id, min_distance, measurement
+
+ def correlation(self, sensor_data):
+ # 遍历传感器进行计算
+ res = {'m_ids':[], 'distances':[], 'measurements':[], 'key_ids':[]}
+ for value in sensor_data:
+ if len(value['id_list']) > 0:
+ m_id, min_distance, measurement = self.one_correlation(value['data_matrix'], value['id_list'])
+ key = value['deviceId']
+ res['m_ids'].append(m_id)
+ res['measurements'].append(measurement)
+ res['key_ids'].append([key, m_id])
+ # 将发生过关联的目标赋予更大的置信度
+ if [key, m_id] in self.origin_set:
+ min_distance = min_distance * 0.2
+ res['distances'].append(min_distance)
+ return res
+
+
+#融合类的构造函数
+class DataFusion:
+ def __init__(self,gate=25,interval = 1,fusion_type = 1,
+ measuremrnt_variance=1,process_variance =1e-1):
+ """
+ 初始化DataFusion类。
+ """
+ # self.task_id = task_id
+ self.interval = interval
+ self.gate = gate
+ self.targets = []
+ self.fusion_type = fusion_type
+ self.existence_thres = 0.01
+ self.show_thres = show_thres
+ self.process_variance = process_variance
+ self.measuremrnt_variance = measuremrnt_variance
+
+ def set_parameter(self,fusion_parms):
+ print("GO!!!!!!!!!")
+ print(fusion_parms)
+
+ def obtain_priority(self,sensor_data):
+ self.priority_dict = dict()
+ for data in sensor_data:
+ if data.get('priority'):
+ self.priority_dict[data['deviceId']] = data['priority']
+ else:
+ self.priority_dict[data['deviceId']] = 1
+
+
+ def out_transformer(self,target):
+ out_former = {
+ 'objectId': target.id,
+ 'survive': target.survive.tolist(),
+ 'state': target.m.tolist(),
+ 'speed': np.linalg.norm(target.v).tolist() / self.interval,
+ 'source': target.source,
+ 'sigma': np.diag(target.P).tolist(),
+ 'X': target.m[0].tolist(),
+ 'Y': target.m[1].tolist(),
+ 'Z': target.m[2].tolist(),
+ 'Vx': target.v[0].tolist(),
+ 'Vy': target.v[1].tolist(),
+ 'Vz': target.v[2].tolist(),
+ 'born_time': str(target.born_time)
+ }
+ return out_former
+
+
+ def run(self, sensor_data):
+ current_time = datetime.datetime.now()
+ run_timestamp = int(current_time.timestamp() * 1000)
+ fusion_data = []
+ selected_list = []
+ self.obtain_priority(sensor_data)
+
+ # 遍历所有已知对象
+ for target in self.targets:
+ print(f"Fusion target id:{target.id} with survive: {target.survive} at :{target.m}\n")
+ if target.survive < self.existence_thres:
+ continue
+ target.predict()
+ res = target.correlation(sensor_data)
+ target.update(res,run_timestamp,self.gate)
+ # ==================================================
+ now_id = []
+ t_sum = 0
+ for r, distance in enumerate(res['distances']):
+ if distance < self.gate:
+ now_id.append(res['key_ids'][r])
+ selected_list.append(res['key_ids'][r])
+ D_Id = res['key_ids'][r][0]
+ t_sum += self.priority_dict[D_Id]
+ target.source = now_id
+ # ==================================================
+ if self.fusion_type == 2 and t_sum < 2:
+ target.survive = target.survive * 0.5
+
+ out_former = self.out_transformer(target)
+ if target.survive > self.show_thres: # 若存活概率大于0.4,则写入数据文件
+ fusion_data.append(out_former)
+
+ # 根据匹配关系筛选数值
+ self.selected_list = selected_list
+ for data in sensor_data:
+ self.new_born(data)
+
+ self.remove_duplicates()
+ # ==================================================
+ self.fusion_process_log(fusion_data)
+
+ return fusion_data
+
+ def new_born(self,value,):
+ for j, id in enumerate(value['id_list']):
+ key = value['deviceId']
+ if [key, id] not in self.selected_list:
+ if self.fusion_type == 3:
+ if value['priority'] > 50:
+ self.targets.append(KalmanFilter(value['data_matrix'][j, :], [key, id],self.measuremrnt_variance,self.process_variance))
+ else:
+ self.targets.append(KalmanFilter(value['data_matrix'][j, :], [key, id],self.measuremrnt_variance,self.process_variance))
+ self.selected_list.append([key, id]) # 把新增的目标,加入到集合中去
+
+ def remove_duplicates(self):
+ # 创建一个空列表用于存储需要删除的列表的索引
+ to_delete = []
+
+ # 遍历所有列表的索引
+ for i in range(len(self.targets)):
+ if self.targets[i].survive < self.existence_thres:
+ to_delete.append(self.targets[i].id)
+ continue
+ if self.targets[i].survive < self.show_thres:
+ continue
+ for j in range(i + 1, len(self.targets)):
+ # 比较两个列表是否相同
+ if are_lists_equal(self.targets[i].source, self.targets[j].source):
+ # 如果列表相同,记录编号较大的索引
+ if self.targets[i].duration < self.targets[j].duration:
+ to_delete.append(self.targets[i].id)
+ else:
+ to_delete.append(self.targets[j].id)
+
+ # 使用删除法,提高目标管理效率
+ for item_id in sorted(to_delete, reverse=True):
+ for target in self.targets:
+ if target.id == item_id:
+ self.targets.remove(target)
+ break
+
+ def fusion_process_log(self,fusion_data):
+ current_time = datetime.datetime.now()
+ # 格式化时间为年月日时分秒格式
+ formatted_time = current_time.strftime('%Y-%m-%d %H:%M:%S')
+ with open('process_log.txt', 'a') as log_file: # 以追加模式打开日志文件
+ log_file.write('=====================\n') # 写入分隔符
+ log_file.write(f"time: {formatted_time}\n") # 写入分隔符
+ log_file.write(f"data:\n {fusion_data}\n") # 写入消息内容
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/KF_main.py b/agent-common/SplitProject/ranjing-python-devfusion/KF_main.py
new file mode 100644
index 0000000..d3faafe
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/KF_main.py
@@ -0,0 +1,53 @@
+from KF_V2 import *
+# ======================
+
+sensor_id_list = ['AUV01','AUV02']
+
+sensor_data = []
+sensor_data.append({
+ 'data_matrix': np.array([[0, 0, 0], [100, 100, 100]]),
+ 'id_list': ['001','002'],
+ 'deviceId': 'AUV01',
+ 'devicePs':[0.2], #第一个值表示测量误差
+ 'latest_time': [0],
+ 'priority':1
+})
+sensor_data.append({
+ 'data_matrix': np.array([[0, 0, 0], [100, 100, 100]]),
+ 'id_list': ['003','004'],
+ 'deviceId': 'AUV02',
+ 'deivceProperties':[0.2],
+ 'latest_time': [0],
+ 'priority':100
+})
+
+
+fusion_container = DataFusion(25,1,3)
+for i in range(15):
+ print(i)
+ # 在循环开始时,对 sensor_data 中的 data_matrix 进行修改
+ if i%5 == 0:
+ temp = {
+ 'data_matrix': np.array([]),
+ 'id_list': [],
+ 'deviceId': 'AUV01',
+ 'devicePs': [0.2], # 第一个值表示测量误差
+ 'latest_time': [0]
+ }
+ c_sensor_data = []
+ c_sensor_data.append(temp)
+ c_sensor_data.append(temp)
+ filted_results = fusion_container.run(c_sensor_data)
+ else:
+ sensor_data[0]['data_matrix'][0, :] += 1 # 第一行每个元素加1
+ sensor_data[0]['data_matrix'][1, :] -= 1 # 第二行每个元素减1
+ sensor_data[1]['data_matrix'][0, :] += 1 # 第一行每个元素加1
+ sensor_data[1]['data_matrix'][1, :] -= 1 # 第二行每个元素减1
+ filted_results = fusion_container.run(sensor_data)
+
+
+
+
+ print("results:\n")
+ for d in filted_results:
+ print(d)
\ No newline at end of file
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/SensorTool.py b/agent-common/SplitProject/ranjing-python-devfusion/SensorTool.py
new file mode 100644
index 0000000..c543fdb
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/SensorTool.py
@@ -0,0 +1,142 @@
+import numpy as np
+from scipy import signal
+
+
+class AoAConverter:
+ def __init__(self):
+ self.p = [1e8, 1e8, 1e8]
+
+ def to_cartesian(self, theta_rad, phi_rad):
+ # theta_rad = np.radians(theta)
+ # phi_rad = np.radians(phi)
+ # 注意!程序输入的是弧度单位
+ """将球坐标转换为直角坐标"""
+ x = np.sin(theta_rad) * np.cos(phi_rad)
+ y = np.sin(theta_rad) * np.sin(phi_rad)
+ z = np.cos(theta_rad)
+ pc =np.array([x,y,z])
+ return pc
+
+ def calc_error(self, pc, mc):
+ # 计算预测坐标与实际观测坐标之间的差的平方
+ mc = np.expand_dims(mc, axis=1)
+ diff_squared = (pc - mc) ** 2
+ # 对差值的平方求和,得到误差的平方
+ error_squared = np.sum(diff_squared, axis=0)
+ # 开平方根得到误差
+ return np.sqrt(error_squared)
+
+ import numpy as np
+
+ def find_best_r(self, theta, phi, mc, r_range):
+ """在给定范围内搜索最优的 r 值"""
+ # 将 r_range 转换为 NumPy 数组,以便进行矢量化操作
+ r_values = np.array(r_range)
+ # 计算所有可能的直角坐标
+ pc = self.to_cartesian(theta, phi)
+ # 进行维度扩充以进行矩阵乘法
+ r_values = np.expand_dims(r_values, axis=0)
+ pc = np.expand_dims(pc, axis=1)
+ # 计算所有 r 值对应的误差
+ # print([pc.shape,r_values.shape])
+ D = np.dot(pc, r_values)
+ errors = self.calc_error(D, mc)
+ r_values = np.squeeze(r_values)
+
+ # 找到最小误差及其对应的 r 值
+ min_error = np.min(errors)
+ best_r = r_values[np.argmin(errors)] #因为多加了一维,所以这里要反求0
+
+ return [best_r,min_error]
+
+ def projected_measure(self,theta, phi, r,p0):
+ pc = self.to_cartesian(theta, phi)
+ neo_p = r*pc + p0
+ return np.array(neo_p)
+
+converter = AoAConverter()
+
+
+def calculate_euclidean_distances(A, BX):
+ # 计算A和B之间的欧式距离
+ B = BX['data_matrix']
+ N = B.shape[0]
+ r_range = np.linspace(-5, 5, 100)
+ if BX.get('AOA_pos'):
+ # 若是来自AOA的数据,则进行替换
+ sensor_pos = BX.get('AOA_pos')
+ ob_pos = A - sensor_pos
+ r0 = np.linalg.norm(ob_pos)
+ B_new = []
+ for i in range(N):
+ theta = B[i,0]
+ phi = B[i,1]
+ [best_r,min_error] = converter.find_best_r(theta, phi,ob_pos, r0+r_range)
+ print(min_error)
+ B_new.append(converter.projected_measure(theta, phi,best_r,sensor_pos))
+ B_new = np.array(B_new)
+ else:
+ B_new = B
+
+
+ distances = np.linalg.norm(A - B_new, axis=1)
+ # 找到最小距离及其索引
+ min_distance_index = np.argmin(distances)
+ min_distance = distances[min_distance_index]
+ return [min_distance, min_distance_index, B_new]
+
+def are_lists_equal(listA, listB):
+ # 对两个列表中的子列表进行排序
+ if len(listA) == 0:
+ return False
+ sorted_listA = sorted(listA, key=lambda x: (x[0], x[1]))
+ sorted_listB = sorted(listB, key=lambda x: (x[0], x[1]))
+ # 比较排序后的列表是否相等
+ return sorted_listA == sorted_listB
+
+def sigmoid(x, a=10, b=0.1):
+ # 调整Sigmoid函数使其在x=4时值为0.5
+ # a和b是调整参数,用于控制函数的形状
+ return 1 / (1 + np.exp(-a * (x - 1))) + b
+
+
+def calculate_correlation(A, B):
+ """
+ 计算两个数组矩阵所有列的相关系数的最大值。
+
+ 参数:
+ A -- 第一个NumPy数组
+ B -- 第二个NumPy数组
+ """
+ A = np.exp(-1j*A/50)
+ B = np.exp(1j*B/50)
+ corr_res = []
+ for col in range(3):
+ a = A[:, col]
+ b = B[:, col]
+ convolution = signal.convolve(a, b[::-1])
+ corr_res.append(convolution)
+ max_corr = np.sum(np.abs(np.array(corr_res)),0)
+ max_corr = np.max(max_corr)/3
+
+ return max_corr
+
+
+def calculate_history_distances(target, b):
+ # 使用前后向的形式进行计算
+ A = target.m_history
+ v = target.v
+ # 计算每一行与向量b的差的L2范数(欧氏距离)
+ if A.shape[0] < 10:
+ return np.inf
+ local_time = np.linspace(0, 10, 20)
+ local_time = np.expand_dims(local_time, axis=1)
+ v = np.expand_dims(v, axis=1)
+ A_pre = A[-10:,0:3]
+ A_post = np.dot(local_time,v.T)
+ A_all = np.vstack((A_pre, A_post))
+ distances = np.linalg.norm(A_all - b, axis=1)
+ # 找到最小距离
+ min_distance = np.min(distances)
+
+ return min_distance
\ No newline at end of file
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/build_devfusion_image.sh b/agent-common/SplitProject/ranjing-python-devfusion/build_devfusion_image.sh
new file mode 100644
index 0000000..2f4ba46
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/build_devfusion_image.sh
@@ -0,0 +1,26 @@
+ #!/bin/bash
+
+ # 使用说明,在主机之上选择你的合适的目录
+ # 上传的最新的项目代码,然后把这个脚本放置于你的项目目录之中
+
+
+
+ # 修改下面的参数
+ if [[ $# -eq 0 ]]; then
+ echo "tag version is null!"
+ exit 233
+ fi
+
+ tag_version=$1
+
+ echo "start to build docker image tag is => ${tag_version}"
+ docker build -t harbor.cdcyy.com.cn/cmii/cmii-uavms-pyfusion:${tag_version} .
+ echo ""
+
+ echo "login to docker hub"
+ docker login -u rad02_drone -p Drone@1234 harbor.cdcyy.com.cn
+
+ echo ""
+
+ echo "start to push image to hub!"
+ docker push harbor.cdcyy.com.cn/cmii/cmii-uavms-pyfusion:${tag_version}
\ No newline at end of file
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/check.py b/agent-common/SplitProject/ranjing-python-devfusion/check.py
new file mode 100644
index 0000000..4555b69
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/check.py
@@ -0,0 +1,374 @@
+import os
+import subprocess
+import paho.mqtt.client as mqtt
+import json
+import time
+import threading
+import logging
+from config import *
+import datetime
+import schedule # 需要先安装: pip install schedule
+import yaml
+
+
+# 读取yaml配置
+def load_mqtt_config():
+ config_path = os.getenv('CONFIG_PATH', 'config.yaml')
+ with open(config_path, 'r') as f:
+ config = yaml.safe_load(f)
+ return config['mqtt'], config['topics']
+
+
+# 获取MQTT和topics配置
+mqtt_config, topics_config = load_mqtt_config()
+
+# 设置日志配置
+logging.basicConfig(
+ level=logging.INFO,
+ format='%(asctime)s - %(levelname)s - %(message)s',
+ handlers=[
+ logging.FileHandler('check.log'),
+ logging.StreamHandler()
+ ]
+)
+
+# 存储运行中的任务及其配置
+running_tasks = {}
+task_configs = {}
+
+# 启动 Dev_Fusion.py 的命令模板
+fusion_command_template = f"nohup python Dev_Fusion.py -t {{task_id}} -g {DEV_FUSION_G} -i {DEV_FUSION_I} > /dev/null 2> error.log &"
+
+# 日志文件夹路径
+log_folder = "tasklog"
+os.makedirs(log_folder, exist_ok=True)
+
+# 创建全局锁
+task_lock = threading.Lock()
+
+
+def compare_configs(old_config, new_config):
+ """
+ 比较两个配置是否有实质性差异
+ 返回 True 表示有差异,需要重启
+ 返回 False 表示无差异,只需转发
+ """
+ try:
+ # 1. 检查 devices 列表
+ old_devices = old_config.get('devices', [])
+ new_devices = new_config.get('devices', [])
+
+ if len(old_devices) != len(new_devices):
+ return True
+
+ # 为每个设备创建一个关键信息元组进行比较
+ def get_device_key(device):
+ return (
+ device.get('device_id'),
+ device.get('device_topic'),
+ device.get('device_type'),
+ device.get('reference_point')
+
+ )
+
+ old_device_keys = {get_device_key(d) for d in old_devices}
+ new_device_keys = {get_device_key(d) for d in new_devices}
+
+ # 如果设备的关键信息有变化,需要重启
+ if old_device_keys != new_device_keys:
+ return True
+
+ # 2. 检查参考点
+ old_ref = old_config.get('reference_point')
+ new_ref = new_config.get('reference_point')
+
+ if old_ref != new_ref:
+ return True
+
+ # 3. 其他参数(如 sampling_rate)的变化不需要重启
+ logging.info("No critical configuration changes detected")
+ return False
+
+ except Exception as e:
+ logging.error(f"Error comparing configs: {str(e)}")
+ return True # 出错时视为有差异,安全起见重启实例
+
+
+def stop_task(task_id):
+ """停止指定的任务实例"""
+ try:
+ if task_id in running_tasks:
+ process = running_tasks[task_id]
+ # 使用 pkill 命令终止对应的 Python 进程
+ subprocess.run(f"pkill -f 'python.*Dev_Fusion.py.*-t {task_id}'", shell=True)
+ process.wait(timeout=5) # 等待进程结束
+ del running_tasks[task_id]
+ del task_configs[task_id]
+ logging.info(f"Task {task_id} stopped successfully")
+ except Exception as e:
+ logging.error(f"Error stopping task {task_id}: {str(e)}")
+
+
+# 多线程处理函数
+def handle_task(client, task_id, payload):
+ try:
+ with task_lock: # 使用锁保护共享资源
+ data = json.loads(payload)
+ sensor_topic = topics_config['sensor_topic'].replace("+", task_id)
+
+ # 记录配置更新
+ log_file = os.path.join(log_folder, f"received_tasklog_{task_id}.txt")
+ current_time = datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')
+
+ def log_config_update(action):
+ with open(log_file, "a") as f:
+ f.write(f"\n=== Configuration Update at {current_time} ===\n")
+ f.write(f"Task ID: {task_id}\n")
+ f.write(f"MQTT_TOPIC: {topics_config['mqtt_topic']}\n")
+ f.write(f"Payload: {payload}\n")
+ f.write(f"Action: {action}\n")
+ f.write("=" * 50 + "\n")
+
+ # 检查任务是否已经在运行
+ if task_id in running_tasks:
+ # 检查是否有存储的配置
+ if task_id in task_configs:
+ # 比较新旧配置
+ if compare_configs(task_configs[task_id], data):
+ logging.info(f"Configuration changed for task {task_id}, restarting...")
+ stop_task(task_id)
+ log_config_update("Configuration changed, restarting instance")
+ start_new_instance(client, task_id, payload, data)
+ else:
+ # 配置无变化,只转发消息
+ logging.info(f"No configuration change for task {task_id}, forwarding message")
+ log_config_update("Message forwarded (no critical changes)")
+ client.publish(sensor_topic, payload)
+ else:
+ # 没有存储的配置,存储新配置并转发
+ logging.info(f"No stored config for task {task_id}, storing first config")
+ task_configs[task_id] = data
+ log_config_update("First config stored and forwarded")
+ client.publish(sensor_topic, payload)
+ else:
+ # 任务不存在,启动新实例
+ log_config_update("New instance started")
+ start_new_instance(client, task_id, payload, data)
+
+ except Exception as e:
+ logging.error(f"Error handling task {task_id}: {str(e)}")
+
+
+def start_new_instance(client, task_id, payload, config):
+ """启动新的 Dev_Fusion 实例"""
+ try:
+ # 启动 Dev_Fusion.py 实例
+ fusion_command = fusion_command_template.format(task_id=task_id)
+ process = subprocess.Popen(fusion_command, shell=True)
+ running_tasks[task_id] = process
+ task_configs[task_id] = config
+
+ logging.info(f"Dev_Fusion.py started successfully for Task ID {task_id}")
+
+ # 保存日志,使用追加模式
+ log_file = os.path.join(log_folder, f"received_tasklog_{task_id}.txt")
+ current_time = datetime.datetime.now().strftime('%Y-%m-%d %H:%M:%S')
+ with open(log_file, "a") as f: # 使用 "a" 模式追加内容
+ f.write(f"\n=== Configuration Update at {current_time} ===\n")
+ f.write(f"Task ID: {task_id}\n")
+ f.write(f"MQTT_TOPIC: {topics_config['mqtt_topic']}\n")
+ f.write(f"Payload: {payload}\n")
+ # 记录是否触发了重启
+ f.write("Action: New instance started\n")
+ f.write("=" * 50 + "\n")
+
+ # 等待实例启动
+ time.sleep(0.5)
+
+ # 发送配置
+ sensor_topic = topics_config['sensor_topic'].replace("+", task_id)
+ client.publish(sensor_topic, payload)
+ logging.info(f"Configuration sent to {sensor_topic}")
+
+ except Exception as e:
+ logging.error(f"Error starting new instance for task {task_id}: {str(e)}")
+ if task_id in running_tasks:
+ del running_tasks[task_id]
+ del task_configs[task_id]
+
+
+# MQTT 回调函数
+def on_connect(client, userdata, flags, rc):
+ if rc == 0:
+ logging.info("Connected to MQTT broker")
+ client.subscribe(topics_config['mqtt_topic']) # 使用yaml中的topic
+ else:
+ logging.error(f"Connection failed with code {rc}: {DISCONNECT_REASONS.get(rc, 'Unknown error')}")
+
+
+def on_message(client, userdata, msg):
+ try:
+ payload = msg.payload.decode("utf-8")
+ logging.info(f"Received message on topic {msg.topic}")
+
+ data = json.loads(payload)
+ task_id = data.get("task_id")
+
+ if task_id:
+ thread = threading.Thread(target=handle_task, args=(client, task_id, payload))
+ thread.start()
+ else:
+ logging.warning("Received message without task_id")
+
+ except json.JSONDecodeError:
+ logging.error("Received message is not valid JSON")
+ except Exception as e:
+ logging.error(f"Error processing message: {str(e)}")
+
+
+def check_running_instances():
+ """检查系统中已经运行的 Dev_Fusion 实例"""
+ try:
+ # 使用 ps 命令查找运行中的 Dev_Fusion.py 实例
+ result = subprocess.run("ps aux | grep 'python.*Dev_Fusion.py' | grep -v grep",
+ shell=True, capture_output=True, text=True)
+
+ found_instances = []
+ for line in result.stdout.splitlines():
+ # 从命令行参数中提取 task_id
+ if '-t' in line:
+ parts = line.split()
+ for i, part in enumerate(parts):
+ if part == '-t' and i + 1 < len(parts):
+ task_id = parts[i + 1]
+ pid = parts[1] # 进程 ID 通常在第二列
+ found_instances.append((task_id, pid))
+
+ for task_id, pid in found_instances:
+ logging.info(f"Found running instance for task {task_id}, pid: {pid}")
+
+ # 读取该任务的最新配置
+ config = read_latest_config(task_id)
+ if config:
+ # 将已运行的实例添加到 running_tasks
+ running_tasks[task_id] = subprocess.Popen(['echo', ''], stdout=subprocess.PIPE)
+ running_tasks[task_id].pid = int(pid)
+ task_configs[task_id] = config
+ logging.info(
+ f"Successfully loaded config for task {task_id} from tasklog/received_tasklog_{task_id}.txt")
+ else:
+ logging.warning(f"No valid config found for task {task_id}, stopping instance...")
+ subprocess.run(f"pkill -f 'python.*Dev_Fusion.py.*-t {task_id}'", shell=True)
+ logging.info(f"Stopped instance {task_id} due to missing config")
+
+ logging.info(f"Finished checking instances. Loaded {len(running_tasks)} tasks with valid configs")
+
+ except Exception as e:
+ logging.error(f"Error checking running instances: {str(e)}")
+
+
+def read_latest_config(task_id):
+ """读取指定任务的最新配置"""
+ try:
+ log_file = os.path.join(log_folder, f"received_tasklog_{task_id}.txt")
+ if not os.path.exists(log_file):
+ logging.error(f"No log file found for task {task_id}")
+ return None
+
+ with open(log_file, 'r') as f:
+ content = f.read()
+
+ # 按配置更新块分割
+ updates = content.split('=== Configuration Update at')
+ if not updates:
+ return None
+
+ # 获取最后一个更新块
+ latest_update = updates[-1]
+
+ # 提取 Payload
+ payload_start = latest_update.find('Payload: ') + len('Payload: ')
+ payload_end = latest_update.find('\nAction:')
+ if payload_end == -1: # 如果没有 Action 行
+ payload_end = latest_update.find('\n===')
+
+ if payload_start > 0 and payload_end > payload_start:
+ payload = latest_update[payload_start:payload_end].strip()
+ return json.loads(payload)
+
+ return None
+ except Exception as e:
+ logging.error(f"Error reading latest config for task {task_id}: {str(e)}")
+ return None
+
+
+def restart_all_instances():
+ """重启所有运行中的实例"""
+ logging.info("Scheduled restart: Beginning restart of all instances")
+
+ # 复制当前运行的任务列表,因为我们会修改 running_tasks
+ tasks_to_restart = list(running_tasks.keys())
+
+ for task_id in tasks_to_restart:
+ try:
+ # 读取最新配置
+ config = read_latest_config(task_id)
+ if not config:
+ logging.error(f"Could not find latest config for task {task_id}, skipping restart")
+ continue
+
+ # 停止当前实例
+ logging.info(f"Stopping task {task_id} for scheduled restart")
+ stop_task(task_id)
+
+ # 将配置转换为 JSON 字符串
+ payload = json.dumps(config)
+
+ # 启动新实例
+ logging.info(f"Starting new instance for task {task_id} with latest config")
+ start_new_instance(mqtt_client, task_id, payload, config)
+
+ except Exception as e:
+ logging.error(f"Error restarting task {task_id}: {str(e)}")
+
+
+def setup_scheduled_restart(restart_time="03:00"):
+ """设置定时重启任务"""
+ schedule.every().day.at(restart_time).do(restart_all_instances)
+
+ def run_schedule():
+ while True:
+ schedule.run_pending()
+ time.sleep(30) # 每30秒检查一次
+
+ # 启动调度器线程
+ scheduler_thread = threading.Thread(target=run_schedule, daemon=True)
+ scheduler_thread.start()
+
+
+def main():
+ global mqtt_client # 添加全局变量以在重启时使用
+
+ # 在启动时检查已运行的实例
+ check_running_instances()
+
+ # 创建 MQTT 客户端
+ mqtt_client = mqtt.Client()
+ mqtt_client.on_connect = on_connect
+ mqtt_client.on_message = on_message
+ mqtt_client.username_pw_set(mqtt_config['username'], mqtt_config['password'])
+
+ # 设置定时重启(默认凌晨3点)
+ setup_scheduled_restart()
+
+ while True:
+ try:
+ mqtt_client.connect(mqtt_config['broker'], mqtt_config['port'], 60)
+ mqtt_client.loop_forever()
+ except Exception as e:
+ logging.error(f"MQTT connection error: {str(e)}")
+ time.sleep(5)
+
+
+if __name__ == "__main__":
+ main()
\ No newline at end of file
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/config-dev.yaml b/agent-common/SplitProject/ranjing-python-devfusion/config-dev.yaml
new file mode 100644
index 0000000..5db0ab6
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/config-dev.yaml
@@ -0,0 +1,10 @@
+mqtt:
+ broker: "192.168.35.178"
+ port: 31884
+ username: "cmlc"
+ password: "4YPk*DS%+5"
+
+topics:
+ mqtt_topic: "bridge/DP74b4ef9fb4aaf269/device_data/FU_PAM/+"
+ sensor_topic: "fromcheck/DP74b4ef9fb4aaf269/device_data/FU_PAM/+"
+
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/config.py b/agent-common/SplitProject/ranjing-python-devfusion/config.py
new file mode 100644
index 0000000..0491216
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/config.py
@@ -0,0 +1,67 @@
+# # MQTT 配置
+# broker = "192.168.35.178" # 代理地址
+# port = 31883 # 端口
+# username = "cmlc"
+# password = "odD8#Ve7.B"
+#
+# # check.py 使用的topic
+# MQTT_TOPIC = "bridge/DP74b4ef9fb4aaf269/device_data/FU_PAM/+"
+#
+# # Dev_Fusion.py 使用的topic
+# SENSOR_TOPIC = "fromcheck/DP74b4ef9fb4aaf269/device_data/FU_PAM/+"
+
+# 在 check 中去配置 Dev_Fusion.py启动命令
+DEV_FUSION_G = 40 # 参数 g
+DEV_FUSION_I = 0.6 # 参数 i
+
+#KF_V2设置
+shift_value = 1
+survive_initial = 0.25
+decay = 0.7
+show_thres = 0.4
+reference_point = (104.08, 30.51)
+
+# logs 配置
+DISCONNECT_REASONS = {
+ 0: "正常断开",
+ 1: "协议版本不匹配",
+ 2: "客户端标识符无效",
+ 3: "服务器不可用",
+ 4: "用户名或密码错误",
+ 5: "未授权",
+ 6: "消息代理不可用",
+ 7: "TLS错误",
+ 8: "QoS不支持",
+ 9: "客户端已被禁止",
+ 10: "服务器繁忙",
+ 11: "客户端已被禁止(证书相关)",
+ 128: "未指定错误",
+ 129: "畸形数据包",
+ 130: "协议错误",
+ 131: "通信错误",
+ 132: "服务器保持连接超时",
+ 133: "服务器内部错误",
+ 134: "服务器正在关闭",
+ 135: "服务器资源不足",
+ 136: "客户端网络套接字错误",
+ 137: "服务器正在关闭连接",
+ 138: "服务器拒绝连接",
+ 139: "服务器不支持该版本",
+ 140: "客户端ID已被使用",
+ 141: "连接速率超限",
+ 142: "最大连接数超限",
+ 143: "保持连接超时",
+ 144: "会话被接管",
+ 145: "连接已断开",
+ 146: "主题别名无效",
+ 147: "数据包太大",
+ 148: "消息速率太高",
+ 149: "配额超限",
+ 150: "管理行为",
+ 151: "无效的负载格式",
+ 152: "保留未支持",
+ 153: "QoS未支持",
+ 154: "使用另一个服务器",
+ 155: "服务器已迁移",
+ 156: "连接不支持",
+}
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/config.yaml b/agent-common/SplitProject/ranjing-python-devfusion/config.yaml
new file mode 100644
index 0000000..2844c2a
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/config.yaml
@@ -0,0 +1,10 @@
+mqtt:
+ broker: "192.168.35.178"
+ port: 31883
+ username: "cmlc"
+ password: "odD8#Ve7.B"
+
+topics:
+ mqtt_topic: "bridge/DP74b4ef9fb4aaf269/device_data/FU_PAM/+"
+ sensor_topic: "fromcheck/DP74b4ef9fb4aaf269/device_data/FU_PAM/+"
+
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/one-build-and-run.ps1 b/agent-common/SplitProject/ranjing-python-devfusion/one-build-and-run.ps1
new file mode 100644
index 0000000..c132156
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/one-build-and-run.ps1
@@ -0,0 +1,19 @@
+
+
+try {
+ $ErrorActionPreference = "Stop"
+
+ Write-Host "1. Uploading binary exec..." -ForegroundColor Green
+ ssh root@192.168.35.71 "mkdir -p /root/wdd/ranjing-python-devfusion/"
+ scp C:\Users\wdd\IdeaProjects\ProjectOctopus\agent-common\SplitProject\ranjing-python-devfusion\* root@192.168.35.71:/root/wdd/ranjing-python-devfusion/
+
+ Write-Host "2. Exec the command ..." -ForegroundColor Blue
+ Write-Host ""
+ Write-Host ""
+ ssh root@192.168.35.71 "cd /root/wdd/ranjing-python-devfusion/ && docker build -t ranjing/dev-fusion:v1.0 ."
+ Write-Host ""
+ Write-Host ""
+} catch {
+ Write-Host "操作失败: $_" -ForegroundColor Red
+ exit 1
+}
\ No newline at end of file
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/requirements.txt b/agent-common/SplitProject/ranjing-python-devfusion/requirements.txt
new file mode 100644
index 0000000..c58f9c8
Binary files /dev/null and b/agent-common/SplitProject/ranjing-python-devfusion/requirements.txt differ
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/run-docker.sh b/agent-common/SplitProject/ranjing-python-devfusion/run-docker.sh
new file mode 100644
index 0000000..d5e48c4
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/run-docker.sh
@@ -0,0 +1,8 @@
+#!/bin/bash
+
+
+docker run --name devfusion \
+ -d \
+ --rm \
+ -v /root/wdd/ranjing-python-devfusion/config-dev.yaml:/dev-fusion/config.yaml \
+ harbor.cdcdyy.com.cn/cmii/cmii-uavms-pyfusion:6.2.0
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/transformation.py b/agent-common/SplitProject/ranjing-python-devfusion/transformation.py
new file mode 100644
index 0000000..bcfc594
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/transformation.py
@@ -0,0 +1,62 @@
+from math import radians, cos, degrees
+from math import radians, degrees, sin, cos, atan2, sqrt
+
+
+def convert_to_cartesian(lat, lon, reference_point):
+ """将经纬度转换为基于参考点的直角坐标,考虑地球椭球模型"""
+ # 地球椭球参数(WGS84)
+ a = 6378137.0 # 长半轴,单位:米
+ f = 1 / 298.257223563 # 扁率
+ e2 = 2 * f - f ** 2 # 第一偏心率平方
+
+ # 提取参考点坐标
+ ref_lat, ref_lon = reference_point
+
+ # 转换成弧度
+ lat_rad = radians(lat)
+ lon_rad = radians(lon)
+ ref_lat_rad = radians(ref_lat)
+ ref_lon_rad = radians(ref_lon)
+
+ # 计算曲率半径
+ N = a / sqrt(1 - e2 * sin(ref_lat_rad) ** 2) # 参考点处的卯酉圈曲率半径
+
+ # 计算基于参考点的平面直角坐标
+ delta_lon = lon_rad - ref_lon_rad
+ X = (N + 0) * cos(ref_lat_rad) * delta_lon
+ Y = (a * (1 - e2)) / (1 - e2 * sin(ref_lat_rad) ** 2) * (lat_rad - ref_lat_rad)
+
+ return X, Y
+
+
+def convert_to_geodetic(x, y, reference_point):
+ """将直角坐标转换为经纬度,考虑地球椭球模型"""
+ # 地球椭球参数(WGS84)
+ a = 6378137.0 # 长半轴,单位:米
+ f = 1 / 298.257223563 # 扁率
+ e2 = 2 * f - f ** 2 # 第一偏心率平方
+
+ # 提取参考点坐标
+ ref_lat, ref_lon = reference_point
+
+ # 转换成弧度
+ ref_lat_rad = radians(ref_lat)
+ ref_lon_rad = radians(ref_lon)
+
+ # 计算曲率半径
+ N = a / sqrt(1 - e2 * sin(ref_lat_rad) ** 2) # 参考点处的卯酉圈曲率半径
+
+ # 计算纬度
+ lat_rad = y * (1 - e2 * sin(ref_lat_rad) ** 2) / (a * (1 - e2)) + ref_lat_rad
+
+ # 计算经度
+ if cos(ref_lat_rad) == 0:
+ lon_rad = 0
+ else:
+ lon_rad = x / ((N + 0) * cos(ref_lat_rad)) + ref_lon_rad
+
+ # 转换回角度
+ lat = degrees(lat_rad)
+ lon = degrees(lon_rad)
+
+ return lat, lon
\ No newline at end of file
diff --git a/agent-common/SplitProject/ranjing-python-devfusion/utils.py b/agent-common/SplitProject/ranjing-python-devfusion/utils.py
new file mode 100644
index 0000000..9cdbd8c
--- /dev/null
+++ b/agent-common/SplitProject/ranjing-python-devfusion/utils.py
@@ -0,0 +1,423 @@
+import datetime
+from transformation import *
+import json
+import numpy as np
+
+
+class Pipeline:
+ def __init__(self, fusion_parameters_topic,reference_point):
+ self.fusion_parameters_topic = fusion_parameters_topic
+ self.task_id = '554343465692430336'
+ self.reference_point = reference_point
+ # self.deviceId = deviceId
+ self.sensor_id_list = ["10000000000"]
+ self.fusionCode = 'DPZYLY'
+ self.publish_topic = f"bridge/{self.fusionCode}/device_data/fusion/{self.task_id}"
+ self.priority_dict = {"10000000000":1}
+ self.uavInfo_bucket = dict()
+ self.target_bowl = dict()
+ self.device_info_dict = dict()
+ self.device_type_mapping = {
+ "5ga": 0,
+ "radar": 1,
+ "spec": 2,
+ "oe": 3,
+ "cm": 4,
+ "dec": 5,
+ "ifr": 6,
+ "cv": 7,
+ "isrs": 8,
+ "aoa": 9,
+ "tdoa": 10,
+ "dcd": 11,
+ "direct": 100,
+ "rtk": 101,
+ "rid": 102,
+ "fusion": 1000,
+ "other": 999 # 假设 'other' 对应于未知设备类型
+ }
+ self.device_type_speedrank = {
+ "radar": 1,
+ "spec": 2,
+ "oe": 3,
+ "cm": 4,
+ "dec": 5,
+ "ifr": 6,
+ "cv": 7,
+ "isrs": 8,
+ "aoa": 9,
+ "tdoa": 10,
+ "dcd": 13,
+ "direct": 12,
+ "5ga": 11,
+ "rid": 14,
+ "rtk": 15,
+ "other": 0 # 假设 'other' 对应于未知设备类型
+ }
+
+ import json
+
+ def process_json_data(self, json_data):
+ """
+ 将 JSON 数据转换为字典,并添加 X 和 Y 属性。
+ """
+ data_dict = json.loads(json_data)
+
+ # 安全访问 'ptTime' 键
+ pt_time = data_dict.get('ptTime')
+ if pt_time is not None:
+ print(pt_time)
+ else:
+ print("Key 'ptTime' not found in data_dict.")
+
+ # 安全访问 'objects' 键
+ objects = data_dict.get('objects')
+ if objects is None:
+ print("Key 'objects' not found in data_dict.")
+ return data_dict # 如果 'objects' 键不存在,直接返回原始字典或根据需要进行其他处理
+
+ # 如果 'objects' 键存在,继续处理
+ for record in objects:
+ # 检查 'latitude' 和 'longitude' 键是否存在于 record 中
+ if 'latitude' in record and 'longitude' in record:
+ lat = record['latitude']
+ lon = record['longitude']
+ X, Y = convert_to_cartesian(lat, lon, self.reference_point)
+ record['X'] = X
+ record['Y'] = Y
+ else:
+ print("Record is missing 'latitude' or 'longitude' keys.")
+
+ return data_dict
+
+ def data_encoder(self, data_list):
+ """
+ 生成数据矩阵和 ID 列表。
+ """
+ sensor_data = []
+ for sensor_id in self.sensor_id_list:
+ temp = {'data_matrix': [],
+ 'id_list': [],
+ 'deviceId': sensor_id,
+ 'latest_time': [],
+ 'priority':1}
+ for record in data_list:
+ if record.get('noteData'):
+ obj = record['noteData']
+ obj['objectId'] = obj['uasId']
+ obj['deviceId'] = obj["extension"]['deviceId']
+ record['objects'] = [obj]
+
+ if record['deviceId'] == sensor_id:
+ temp['priority'] = self.priority_dict[sensor_id]
+ if record.get('objects'):
+ for obj in record['objects']:
+ if obj['objectId'] in temp['id_list']:
+ position = temp['id_list'].index(obj['objectId'])
+ if int(record['ptTime']) > int(temp['latest_time'][position]):
+ temp['data_matrix'][position] = [obj['X'], obj['Y'], obj['altitude']]
+ else:
+ temp['data_matrix'].append([obj['X'], obj['Y'], obj['altitude']])
+ temp['id_list'].append(obj['objectId'])
+ temp['latest_time'].append(record['ptTime'])
+ # 把扩展地段写入
+ if obj.get('extension'):
+ B_id = str(record['deviceId'])+str(obj['objectId'])
+ self.uavInfo_bucket[B_id] = obj['extension']
+ # 如果对象有speed字段,将其添加到extension中
+ if obj.get('speed'):
+ self.uavInfo_bucket[B_id]['speed'] = obj['speed']
+ # 如果对象有height字段,也存储它
+ if obj.get('height'):
+ self.uavInfo_bucket[B_id]['height'] = obj['height']
+
+ # 写入到数据字典中
+ temp['data_matrix'] = np.array(temp['data_matrix'])
+ sensor_data.append(temp)
+ return sensor_data
+
+ def process_extension(self, target):
+ # 定义一个字典,包含给定的键值对
+ extension = {
+ "objectType": 30,
+ "uavSN": "Un-known",
+ "uavModel": "Un-known",
+ "pilotLat": 0.0,
+ "pilotLon": 0.0,
+ "speedX": 0.0,
+ "speedY": 0.0,
+ "speedZ": 0.0,
+ "time": 0.0,
+ "born_time": 0.0
+ }
+
+ # 从target_bowl获取历史值
+ if target['objectId'] in self.target_bowl.keys():
+ extension = self.target_bowl[target['objectId']]
+
+ result_source = target['source']
+ # 对数据进行更新
+ for source in result_source:
+ id = str(source[0]) + str(source[1])
+ if self.uavInfo_bucket.get(id):
+ for key, value in self.uavInfo_bucket[id].items():
+ # 只有当新值是有效值时才更新
+ if value not in ["Un-known", 0.0, None, "Unknown", "DJI Mavic"]:
+ extension[key] = value
+
+ extension['born_time'] = int(target['born_time'])
+
+ # 更新target_bowl以保持状态
+ self.target_bowl[target['objectId']] = extension
+
+ return extension
+
+ def data_decoder(self, filtered_results):
+ """
+ 解码过滤后的结果。
+ """
+ current_time = datetime.datetime.now()
+ timestamp = int(current_time.timestamp() * 1000)
+ combined_objects = []
+ for target in filtered_results:
+ X = target['X']
+ Y = target['Y']
+ Z = target['Z'] # 这里的Z实际上是altitude
+ lat, lon = convert_to_geodetic(X, Y, self.reference_point)
+ extension = self.process_extension(target)
+ extension['time'] = int(timestamp)
+ extension['born_time'] = int(int(target['born_time']) / 1000) # 毫秒单位数据
+
+ new_origin_source = []
+ for source in target['source']:
+ device_id, object_id = source
+ # 从 device_info_dict 获取设备缩写
+ device_abbreviation = self.device_info_dict.get(device_id, {}).get('device_type', 'other')
+ # 使用映射字典获取设备类型
+ device_type = self.device_type_mapping.get(device_abbreviation, 999)
+ new_origin_source.append(f"{device_type}_{device_id}_{object_id}")
+
+ # 根据优先级顺序选择速度
+ highest_priority_speed = None
+ highest_priority = float('inf')
+
+ for source in target['source']:
+ device_id, object_id = source
+ B_id = str(device_id) + str(object_id)
+ if self.uavInfo_bucket.get(B_id):
+ device_type = self.device_info_dict.get(device_id, {}).get('device_type', 'other')
+ priority = self.device_type_speedrank.get(device_type, float('inf'))
+
+ if priority < highest_priority:
+ highest_priority = priority
+ # 获取速度并进行单位转换
+ speed = self.uavInfo_bucket[B_id].get('speed', target['speed'])
+ if device_type == "5ga": # 如果设备类型是5ga,进行转换
+ speed = speed / 3.6 # 从 km/h 转换为 m/s
+ highest_priority_speed = speed
+
+ # 确保 highest_priority_speed 是从设备获取的速度
+ if highest_priority_speed is None:
+ # 如果没有找到当前速度,查找历史记录中的速度
+ for obj in reversed(combined_objects):
+ if obj["objectId"] == target['objectId']:
+ highest_priority_speed = obj.get("speed")
+ break
+
+ if highest_priority_speed is None:
+ print(f"Warning: No speed found for target {target['objectId']}, using default target speed.")
+ new_speed = target['speed']
+ else:
+ new_speed = highest_priority_speed
+ else:
+ new_speed = highest_priority_speed
+
+ # Debug 输出,检查速度来源
+ print(f"Selected speed for target {target['objectId']}: {new_speed} from device with priority {highest_priority}")
+
+ # 获取height字段
+ height = None
+ for source in target['source']:
+ device_id, object_id = source
+ B_id = str(device_id) + str(object_id)
+ if self.uavInfo_bucket.get(B_id):
+ if self.uavInfo_bucket[B_id].get('height'):
+ height = self.uavInfo_bucket[B_id]['height']
+ break
+
+ # 如果当前没有获取到height,查找历史记录中的height
+ if height is None:
+ for obj in reversed(combined_objects):
+ if obj["objectId"] == target['objectId']:
+ prev_height = obj.get("height")
+ if prev_height is not None: # 如果找到有效的历史height
+ height = prev_height
+ break
+
+ # 如果仍然没有找到height,保持上一次的最新历史height
+ if height is None and combined_objects:
+ for obj in reversed(combined_objects):
+ if obj["objectId"] == target['objectId']:
+ height = obj.get("height")
+ break
+
+ temp = {
+ # "msg_cnt":result['msg_cnt'],#增加msg_cnt用于检测有无丢包
+ "objectId": target['objectId'],
+ "X": X,
+ "Y": Y,
+ "height": height, # 使用当前height或历史height
+ "altitude": Z,
+ "speed": new_speed, # 使用优先级最高的速度
+ 'latitude': lat,
+ 'longitude': lon,
+ 'sigma': target['sigma'],
+ "extension": {
+ "origin_source": new_origin_source, # 更新后的 origin_source
+ # 其他extension字段...
+ "objectType": extension.get('objectType', 0),
+ "uavSN": extension.get("uavSN", "Un-known"),
+ "uavModel": extension.get("uavModel", "Un-known"),
+ "pilotLat": extension.get("pilotLat", 0.0),
+ "pilotLon": extension.get("pilotLon", 0.0),
+ "speedX": 0.0, # 不再使用速度分量
+ "speedY": 0.0,
+ "speedZ": 0.0,
+ "time": int(timestamp),
+ "born_time": int(int(target['born_time']) / 1000),
+ },
+ "time": int(timestamp),
+ }
+
+ # 检查extension中的objectType是否已经被设置为非0值,如果是,则不再覆盖.
+ if extension.get('objectType', 0) != 0 or target['objectId'] not in [obj['objectId'] for obj in
+ combined_objects]:
+ temp["extension"]["objectType"] = extension.get('objectType', 0)
+ else:
+ # 查找combined_objects中相同objectId的objectType,如果不存在则使用0
+ existing_object_types = [obj["extension"].get('objectType', 0) for obj in combined_objects if
+ obj["objectId"] == target['objectId']]
+ if existing_object_types and existing_object_types[0] != 0:
+ temp["extension"]["objectType"] = existing_object_types[0]
+ else:
+ temp["extension"]["objectType"] = 0
+
+ # 检查并更新uavSN和uavModel
+ invalid_values = ["Un-known", 0.0, None, "Unknown", "DJI Mavic"]
+
+ # 检查uavSN是否为字母数字组合防止其他部分引入奇怪的值
+ current_sn = extension.get('uavSN', "Un-known")
+ if isinstance(current_sn, str):
+ has_letter = any(c.isalpha() for c in current_sn)
+ has_digit = any(c.isdigit() for c in current_sn)
+ if not (has_letter and has_digit):
+ # 先查找相同objectId的历史有效SN
+ for obj in reversed(combined_objects):
+ if obj["objectId"] == target['objectId']:
+ prev_sn = obj["extension"].get("uavSN", "Un-known")
+ if isinstance(prev_sn, str):
+ has_letter = any(c.isalpha() for c in prev_sn)
+ has_digit = any(c.isdigit() for c in prev_sn)
+ if has_letter and has_digit:
+ current_sn = prev_sn
+ break
+ temp["extension"]["uavSN"] = current_sn
+ temp["extension"]["uavModel"] = extension.get('uavModel', "Un-known")
+
+ combined_objects.append(temp)
+
+ data_processed = {
+ "deviceType": 1000,
+ "providerCode": "DPZYLY",
+ "deviceId": self.task_id,
+ "objects": combined_objects,
+ "ptTime": int(timestamp)
+ }
+ # 筛选有意义的数据
+ if data_processed and data_processed.get("objects") and len(data_processed["objects"]) > 0:
+ formatted_time = current_time.strftime('%Y-%m-%d %H:%M:%S')
+ with open('PB_log.txt', 'a') as log_file: # 以追加模式打开日志文件
+ log_file.write('=====================\n') # 写入分隔符
+ log_file.write(f"time: {formatted_time}\n") # 写入时间戳
+ log_file.write(f"data: {data_processed}\n")
+ return data_processed
+
+ def extract_parms(self, parm_data):
+ """
+ 提取参数。
+ """
+ id_list = [] # 存储设备ID
+ priority_dict = {} # 存储设备优先级
+ device_info_dict = {} # 新增:存储设备详细信息的字典,用于后续拿到与
+
+ data_dict = json.loads(parm_data)
+ print(data_dict)
+ self.task_id = data_dict['task_id']
+ new_topics = [("fromcheck/DPZYLY/fly_data/rtk/#", 0)]
+
+ devices = data_dict['devices']
+ for device in devices:
+ device_id = device['device_id']
+ if device_id:
+ id_list.append(device_id)
+ new_topics.append((device["device_topic"], 0))
+
+ # 存储设备优先级,默认优先级为1
+ if device.get('priority'):
+ priority_dict[device_id] = device['priority']
+ else:
+ priority_dict[device_id] = 1
+
+ # 使用列表存储设备的详细信息(topic、type、sampling_rate),完成一对多
+ device_info_dict[device_id] = {
+ 'device_topic': device['device_topic'],
+ 'device_type': device['device_type'],
+ 'sampling_rate': device['properties'].get('sampling_rate', 1) # 默认为None,如果没有提供
+ }
+
+ self.priority_dict = priority_dict
+ self.device_info_dict = device_info_dict # 将设备信息字典存储到实例变量中
+ self.sensor_id_list = id_list
+
+ # 处理参考点
+ if data_dict.get('reference_point'):
+ try:
+ original_reference_point = data_dict['reference_point']
+ if len(original_reference_point) == 2: # 确保是包含两个元素的元组或列表
+ self.reference_point = (
+ float(original_reference_point[0]) + 0,
+ float(original_reference_point[1]) + 0
+ )
+ else:
+ raise ValueError("Invalid reference_point structure. Must be a tuple or list with two elements.")
+ except Exception as e:
+ print(f"Error processing reference_point: {e}")
+ self.reference_point = None # 或者设置为某个默认值
+
+ return new_topics
+
+ def extract_fusion_parms(self,parm_data):
+ data_dict = json.loads(parm_data)
+ # 定义 fusion_dict 字典,包含需要从 data_dict 中提取的键
+ fusion_dict = {
+ "fusion_type": 1,
+ "gate": 1,
+ "interval": 1,
+ "show_thres": 0.4
+ }
+
+ # 检查 data_dict 中是否存在对应的键,并更新 fusion_dict 中的值
+ if "fusion_type" in data_dict:
+ fusion_dict["fusion_type"] = data_dict["fusion_type"]
+
+ if "gate" in data_dict:
+ fusion_dict["gate"] = data_dict["gate"]
+
+ if "interval" in data_dict:
+ fusion_dict["interval"] = data_dict["interval"]
+
+ if "show_thres" in data_dict:
+ fusion_dict["show_thres"] = data_dict["show_thres"]
+
+ # 返回更新后的 fusion_dict
+ return fusion_dict
diff --git a/agent-common/SplitProject/监管平台-Doris-集群部署/doris-configmap.yaml b/agent-common/SplitProject/监管平台-Doris-集群部署/doris-configmap.yaml
new file mode 100644
index 0000000..b8fbaed
--- /dev/null
+++ b/agent-common/SplitProject/监管平台-Doris-集群部署/doris-configmap.yaml
@@ -0,0 +1,71 @@
+apiVersion: v1
+kind: ConfigMap
+metadata:
+ name: fe-configmap
+ namespace: doriscluster
+ labels:
+ app.kubernetes.io/component: fe
+data:
+ fe.conf: |
+ CUR_DATE=`date +%Y%m%d-%H%M%S`
+
+ # the output dir of stderr and stdout
+ LOG_DIR = ${DORIS_HOME}/log
+
+ JAVA_OPTS="-Djavax.security.auth.useSubjectCredsOnly=false -Xss4m -Xmx8192m -XX:+UseMembar -XX:SurvivorRatio=8 -XX:MaxTenuringThreshold=7 -XX:+PrintGCDateStamps -XX:+PrintGCDetails -XX:+UseConcMarkSweepGC -XX:+UseParNewGC -XX:+CMSClassUnloadingEnabled -XX:-CMSParallelRemarkEnabled -XX:CMSInitiatingOccupancyFraction=80 -XX:SoftRefLRUPolicyMSPerMB=0 -Xloggc:$DORIS_HOME/log/fe.gc.log.$CUR_DATE"
+
+ # For jdk 9+, this JAVA_OPTS will be used as default JVM options
+ JAVA_OPTS_FOR_JDK_9="-Djavax.security.auth.useSubjectCredsOnly=false -Xss4m -Xmx8192m -XX:SurvivorRatio=8 -XX:MaxTenuringThreshold=7 -XX:+CMSClassUnloadingEnabled -XX:-CMSParallelRemarkEnabled -XX:CMSInitiatingOccupancyFraction=80 -XX:SoftRefLRUPolicyMSPerMB=0 -Xlog:gc*:$DORIS_HOME/log/fe.gc.log.$CUR_DATE:time"
+
+ # INFO, WARN, ERROR, FATAL
+ sys_log_level = INFO
+
+ # NORMAL, BRIEF, ASYNC
+ sys_log_mode = NORMAL
+
+ # Default dirs to put jdbc drivers,default value is ${DORIS_HOME}/jdbc_drivers
+ # jdbc_drivers_dir = ${DORIS_HOME}/jdbc_drivers
+
+ http_port = 8030
+ arrow_flight_sql_port = 9090
+ rpc_port = 9020
+ query_port = 9030
+ edit_log_port = 9010
+
+ enable_fqdn_mode = true
+---
+apiVersion: v1
+kind: ConfigMap
+metadata:
+ name: be-configmap
+ namespace: doriscluster
+ labels:
+ app.kubernetes.io/component: be
+data:
+ be.conf: |
+ CUR_DATE=`date +%Y%m%d-%H%M%S`
+
+ PPROF_TMPDIR="$DORIS_HOME/log/"
+
+ JAVA_OPTS="-Xmx1024m -DlogPath=$DORIS_HOME/log/jni.log -Xloggc:$DORIS_HOME/log/be.gc.log.$CUR_DATE -Djavax.security.auth.useSubjectCredsOnly=false -Dsun.java.command=DorisBE -XX:-CriticalJNINatives -DJDBC_MIN_POOL=1 -DJDBC_MAX_POOL=100 -DJDBC_MAX_IDLE_TIME=300000 -DJDBC_MAX_WAIT_TIME=5000"
+
+ # For jdk 9+, this JAVA_OPTS will be used as default JVM options
+ JAVA_OPTS_FOR_JDK_9="-Xmx1024m -DlogPath=$DORIS_HOME/log/jni.log -Xlog:gc:$DORIS_HOME/log/be.gc.log.$CUR_DATE -Djavax.security.auth.useSubjectCredsOnly=false -Dsun.java.command=DorisBE -XX:-CriticalJNINatives -DJDBC_MIN_POOL=1 -DJDBC_MAX_POOL=100 -DJDBC_MAX_IDLE_TIME=300000 -DJDBC_MAX_WAIT_TIME=5000"
+
+ # since 1.2, the JAVA_HOME need to be set to run BE process.
+ # JAVA_HOME=/path/to/jdk/
+
+ # https://github.com/apache/doris/blob/master/docs/zh-CN/community/developer-guide/debug-tool.md#jemalloc-heap-profile
+ # https://jemalloc.net/jemalloc.3.html
+ JEMALLOC_CONF="percpu_arena:percpu,background_thread:true,metadata_thp:auto,muzzy_decay_ms:15000,dirty_decay_ms:15000,oversize_threshold:0,lg_tcache_max:20,prof:false,lg_prof_interval:32,lg_prof_sample:19,prof_gdump:false,prof_accum:false,prof_leak:false,prof_final:false"
+ JEMALLOC_PROF_PRFIX=""
+
+ # INFO, WARNING, ERROR, FATAL
+ sys_log_level = INFO
+
+ # ports for admin, web, heartbeat service
+ be_port = 9060
+ webserver_port = 8040
+ heartbeat_service_port = 9050
+ arrow_flight_sql_port = 39091
+ brpc_port = 8060
diff --git a/agent-common/SplitProject/监管平台-Doris-集群部署/doris-deplyment.yaml b/agent-common/SplitProject/监管平台-Doris-集群部署/doris-deplyment.yaml
new file mode 100644
index 0000000..47d1cba
--- /dev/null
+++ b/agent-common/SplitProject/监管平台-Doris-集群部署/doris-deplyment.yaml
@@ -0,0 +1,101 @@
+apiVersion: doris.selectdb.com/v1
+kind: DorisCluster
+metadata:
+ labels:
+ app.kubernetes.io/name: doriscluster
+ name: doriscluster-helm
+ namespace: doriscluster
+spec:
+ feSpec:
+ replicas: 1
+ image: harbor.cdcyy.com.cn/cmii/doris.fe-ubuntu:2.1.6
+ limits:
+ cpu: 8
+ memory: 16Gi
+ requests:
+ cpu: 2
+ memory: 6Gi
+ configMapInfo:
+ # use kubectl create configmap fe-configmap --from-file=fe.conf
+ configMapName: fe-configmap
+ resolveKey: fe.conf
+ nodeSelector:
+ uavcloud.env: demo
+ persistentVolumes:
+ - mountPath: /opt/apache-doris/fe/doris-meta
+ name: doriscluster-storage0
+ persistentVolumeClaimSpec:
+ # when use specific storageclass, the storageClassName should reConfig, example as annotation.
+ storageClassName: nfs-prod-distribute
+ accessModes:
+ - ReadWriteOnce
+ resources:
+ # notice: if the storage size less 5G, fe will not start normal.
+ requests:
+ storage: 300Gi
+ - mountPath: /opt/apache-doris/fe/log
+ name: doriscluster-storage1
+ persistentVolumeClaimSpec:
+ # when use specific storageclass, the storageClassName should reConfig, example as annotation.
+ storageClassName: nfs-prod-distribute
+ accessModes:
+ - ReadWriteOnce
+ resources:
+ requests:
+ storage: 100Gi
+ - mountPath: /opt/apache-doris/fe/jdbc_drivers
+ name: doriscluster-storage-fe-jdbc-drivers
+ persistentVolumeClaimSpec:
+ # when use specific storageclass, the storageClassName should reConfig, example as annotation.
+ storageClassName: nfs-prod-distribute
+ accessModes:
+ - ReadWriteOnce
+ resources:
+ requests:
+ storage: 100Gi
+ beSpec:
+ replicas: 3
+ image: harbor.cdcyy.com.cn/cmii/doris.be-ubuntu:2.1.6
+ limits:
+ cpu: 8
+ memory: 24Gi
+ requests:
+ cpu: 2
+ memory: 6Gi
+ configMapInfo:
+ # use kubectl create configmap be-configmap --from-file=be.conf
+ configMapName: be-configmap
+ resolveKey: be.conf
+ nodeSelector:
+ uavcloud.env: demo
+ persistentVolumes:
+ - mountPath: /opt/apache-doris/be/storage
+ name: doriscluster-storage2
+ persistentVolumeClaimSpec:
+ # when use specific storageclass, the storageClassName should reConfig, example as annotation.
+ storageClassName: nfs-prod-distribute
+ accessModes:
+ - ReadWriteOnce
+ resources:
+ requests:
+ storage: 300Gi
+ - mountPath: /opt/apache-doris/be/log
+ name: doriscluster-storage3
+ persistentVolumeClaimSpec:
+ # when use specific storageclass, the storageClassName should reConfig, example as annotation.
+ storageClassName: nfs-prod-distribute
+ accessModes:
+ - ReadWriteOnce
+ resources:
+ requests:
+ storage: 100Gi
+ - mountPath: /opt/apache-doris/be/jdbc_drivers
+ name: doriscluster-storage-be-jdbc-drivers
+ persistentVolumeClaimSpec:
+ # when use specific storageclass, the storageClassName should reConfig, example as annotation.
+ storageClassName: nfs-prod-distribute
+ accessModes:
+ - ReadWriteOnce
+ resources:
+ requests:
+ storage: 100Gi
\ No newline at end of file
diff --git a/agent-common/SplitProject/监管平台-Doris-集群部署/doris-kind.yaml b/agent-common/SplitProject/监管平台-Doris-集群部署/doris-kind.yaml
new file mode 100644
index 0000000..043b1bc
--- /dev/null
+++ b/agent-common/SplitProject/监管平台-Doris-集群部署/doris-kind.yaml
@@ -0,0 +1,7443 @@
+---
+apiVersion: apiextensions.k8s.io/v1
+kind: CustomResourceDefinition
+metadata:
+ annotations:
+ controller-gen.kubebuilder.io/version: v0.11.3
+ creationTimestamp: null
+ name: dorisclusters.doris.selectdb.com
+spec:
+ group: doris.selectdb.com
+ names:
+ kind: DorisCluster
+ listKind: DorisClusterList
+ plural: dorisclusters
+ shortNames:
+ - dcr
+ singular: doriscluster
+ scope: Namespaced
+ versions:
+ - additionalPrinterColumns:
+ - jsonPath: .status.feStatus.componentCondition.phase
+ name: FeStatus
+ type: string
+ - jsonPath: .status.beStatus.componentCondition.phase
+ name: BeStatus
+ type: string
+ - jsonPath: .status.cnStatus.componentCondition.phase
+ name: CnStatus
+ type: string
+ - jsonPath: .status.brokerStatus.componentCondition.phase
+ name: BrokerStatus
+ type: string
+ name: v1
+ schema:
+ openAPIV3Schema:
+ description: DorisCluster is the Schema for the dorisclusters API
+ properties:
+ apiVersion:
+ description: 'APIVersion defines the versioned schema of this representation
+ of an object. Servers should convert recognized schemas to the latest
+ internal value, and may reject unrecognized values. More info: https://git.k8s.io/community/contributors/devel/sig-architecture/api-conventions.md#resources'
+ type: string
+ kind:
+ description: 'Kind is a string value representing the REST resource this
+ object represents. Servers may infer this from the endpoint the client
+ submits requests to. Cannot be updated. In CamelCase. More info: https://git.k8s.io/community/contributors/devel/sig-architecture/api-conventions.md#types-kinds'
+ type: string
+ metadata:
+ type: object
+ spec:
+ description: DorisClusterSpec defines the desired state of DorisCluster
+ properties:
+ adminUser:
+ description: administrator for register or drop component from fe
+ cluster. adminUser for all component register and operator drop
+ component.
+ properties:
+ name:
+ description: the user name for admin service's node.
+ type: string
+ password:
+ description: password, login to doris db.
+ type: string
+ type: object
+ authSecret:
+ description: the name of secret that type is `kubernetes.io/basic-auth`
+ and contains keys username, password for management doris node in
+ cluster as fe, be register. the password key is `password`. the
+ username defaults to `root` and is omitempty.
+ type: string
+ beSpec:
+ description: defines the be cluster state pod that will be created
+ by operator.
+ properties:
+ affinity:
+ description: If specified, the pod's scheduling constraints.
+ properties:
+ nodeAffinity:
+ description: Describes node affinity scheduling rules for
+ the pod.
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ description: The scheduler will prefer to schedule pods
+ to nodes that satisfy the affinity expressions specified
+ by this field, but it may choose a node that violates
+ one or more of the expressions. The node that is most
+ preferred is the one with the greatest sum of weights,
+ i.e. for each node that meets all of the scheduling
+ requirements (resource request, requiredDuringScheduling
+ affinity expressions, etc.), compute a sum by iterating
+ through the elements of this field and adding "weight"
+ to the sum if the node matches the corresponding matchExpressions;
+ the node(s) with the highest sum are the most preferred.
+ items:
+ description: An empty preferred scheduling term matches
+ all objects with implicit weight 0 (i.e. it's a no-op).
+ A null preferred scheduling term matches no objects
+ (i.e. is also a no-op).
+ properties:
+ preference:
+ description: A node selector term, associated with
+ the corresponding weight.
+ properties:
+ matchExpressions:
+ description: A list of node selector requirements
+ by node's labels.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchFields:
+ description: A list of node selector requirements
+ by node's fields.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ type: object
+ x-kubernetes-map-type: atomic
+ weight:
+ description: Weight associated with matching the
+ corresponding nodeSelectorTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - preference
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ description: If the affinity requirements specified by
+ this field are not met at scheduling time, the pod will
+ not be scheduled onto the node. If the affinity requirements
+ specified by this field cease to be met at some point
+ during pod execution (e.g. due to an update), the system
+ may or may not try to eventually evict the pod from
+ its node.
+ properties:
+ nodeSelectorTerms:
+ description: Required. A list of node selector terms.
+ The terms are ORed.
+ items:
+ description: A null or empty node selector term
+ matches no objects. The requirements of them are
+ ANDed. The TopologySelectorTerm type implements
+ a subset of the NodeSelectorTerm.
+ properties:
+ matchExpressions:
+ description: A list of node selector requirements
+ by node's labels.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchFields:
+ description: A list of node selector requirements
+ by node's fields.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ type: object
+ x-kubernetes-map-type: atomic
+ type: array
+ required:
+ - nodeSelectorTerms
+ type: object
+ x-kubernetes-map-type: atomic
+ type: object
+ podAffinity:
+ description: Describes pod affinity scheduling rules (e.g.
+ co-locate this pod in the same node, zone, etc. as some
+ other pod(s)).
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ description: The scheduler will prefer to schedule pods
+ to nodes that satisfy the affinity expressions specified
+ by this field, but it may choose a node that violates
+ one or more of the expressions. The node that is most
+ preferred is the one with the greatest sum of weights,
+ i.e. for each node that meets all of the scheduling
+ requirements (resource request, requiredDuringScheduling
+ affinity expressions, etc.), compute a sum by iterating
+ through the elements of this field and adding "weight"
+ to the sum if the node has pods which matches the corresponding
+ podAffinityTerm; the node(s) with the highest sum are
+ the most preferred.
+ items:
+ description: The weights of all of the matched WeightedPodAffinityTerm
+ fields are added per-node to find the most preferred
+ node(s)
+ properties:
+ podAffinityTerm:
+ description: Required. A pod affinity term, associated
+ with the corresponding weight.
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by
+ this field and the ones listed in the namespaces
+ field. null selector and null or empty namespaces
+ list means "this pod's namespace". An empty
+ selector ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to.
+ The term is applied to the union of the namespaces
+ listed in this field and the ones selected
+ by namespaceSelector. null or empty namespaces
+ list and null namespaceSelector means "this
+ pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the
+ pods matching the labelSelector in the specified
+ namespaces, where co-located is defined as
+ running on a node whose value of the label
+ with key topologyKey matches that of any node
+ on which any of the selected pods is running.
+ Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ weight:
+ description: weight associated with matching the
+ corresponding podAffinityTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - podAffinityTerm
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ description: If the affinity requirements specified by
+ this field are not met at scheduling time, the pod will
+ not be scheduled onto the node. If the affinity requirements
+ specified by this field cease to be met at some point
+ during pod execution (e.g. due to a pod label update),
+ the system may or may not try to eventually evict the
+ pod from its node. When there are multiple elements,
+ the lists of nodes corresponding to each podAffinityTerm
+ are intersected, i.e. all terms must be satisfied.
+ items:
+ description: Defines a set of pods (namely those matching
+ the labelSelector relative to the given namespace(s))
+ that this pod should be co-located (affinity) or not
+ co-located (anti-affinity) with, where co-located
+ is defined as running on a node whose value of the
+ label with key matches that of any node
+ on which a pod of the set of pods is running
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by this
+ field and the ones listed in the namespaces field.
+ null selector and null or empty namespaces list
+ means "this pod's namespace". An empty selector
+ ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to. The
+ term is applied to the union of the namespaces
+ listed in this field and the ones selected by
+ namespaceSelector. null or empty namespaces list
+ and null namespaceSelector means "this pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the pods
+ matching the labelSelector in the specified namespaces,
+ where co-located is defined as running on a node
+ whose value of the label with key topologyKey
+ matches that of any node on which any of the selected
+ pods is running. Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ type: array
+ type: object
+ podAntiAffinity:
+ description: Describes pod anti-affinity scheduling rules
+ (e.g. avoid putting this pod in the same node, zone, etc.
+ as some other pod(s)).
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ description: The scheduler will prefer to schedule pods
+ to nodes that satisfy the anti-affinity expressions
+ specified by this field, but it may choose a node that
+ violates one or more of the expressions. The node that
+ is most preferred is the one with the greatest sum of
+ weights, i.e. for each node that meets all of the scheduling
+ requirements (resource request, requiredDuringScheduling
+ anti-affinity expressions, etc.), compute a sum by iterating
+ through the elements of this field and adding "weight"
+ to the sum if the node has pods which matches the corresponding
+ podAffinityTerm; the node(s) with the highest sum are
+ the most preferred.
+ items:
+ description: The weights of all of the matched WeightedPodAffinityTerm
+ fields are added per-node to find the most preferred
+ node(s)
+ properties:
+ podAffinityTerm:
+ description: Required. A pod affinity term, associated
+ with the corresponding weight.
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by
+ this field and the ones listed in the namespaces
+ field. null selector and null or empty namespaces
+ list means "this pod's namespace". An empty
+ selector ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to.
+ The term is applied to the union of the namespaces
+ listed in this field and the ones selected
+ by namespaceSelector. null or empty namespaces
+ list and null namespaceSelector means "this
+ pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the
+ pods matching the labelSelector in the specified
+ namespaces, where co-located is defined as
+ running on a node whose value of the label
+ with key topologyKey matches that of any node
+ on which any of the selected pods is running.
+ Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ weight:
+ description: weight associated with matching the
+ corresponding podAffinityTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - podAffinityTerm
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ description: If the anti-affinity requirements specified
+ by this field are not met at scheduling time, the pod
+ will not be scheduled onto the node. If the anti-affinity
+ requirements specified by this field cease to be met
+ at some point during pod execution (e.g. due to a pod
+ label update), the system may or may not try to eventually
+ evict the pod from its node. When there are multiple
+ elements, the lists of nodes corresponding to each podAffinityTerm
+ are intersected, i.e. all terms must be satisfied.
+ items:
+ description: Defines a set of pods (namely those matching
+ the labelSelector relative to the given namespace(s))
+ that this pod should be co-located (affinity) or not
+ co-located (anti-affinity) with, where co-located
+ is defined as running on a node whose value of the
+ label with key matches that of any node
+ on which a pod of the set of pods is running
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by this
+ field and the ones listed in the namespaces field.
+ null selector and null or empty namespaces list
+ means "this pod's namespace". An empty selector
+ ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to. The
+ term is applied to the union of the namespaces
+ listed in this field and the ones selected by
+ namespaceSelector. null or empty namespaces list
+ and null namespaceSelector means "this pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the pods
+ matching the labelSelector in the specified namespaces,
+ where co-located is defined as running on a node
+ whose value of the label with key topologyKey
+ matches that of any node on which any of the selected
+ pods is running. Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ type: array
+ type: object
+ type: object
+ annotations:
+ additionalProperties:
+ type: string
+ description: annotation for fe pods. user can config monitor annotation
+ for collect to monitor system.
+ type: object
+ claims:
+ description: "Claims lists the names of resources, defined in
+ spec.resourceClaims, that are used by this container. \n This
+ is an alpha field and requires enabling the DynamicResourceAllocation
+ feature gate. \n This field is immutable."
+ items:
+ description: ResourceClaim references one entry in PodSpec.ResourceClaims.
+ properties:
+ name:
+ description: Name must match the name of one entry in pod.spec.resourceClaims
+ of the Pod where this field is used. It makes that resource
+ available inside a container.
+ type: string
+ required:
+ - name
+ type: object
+ type: array
+ x-kubernetes-list-map-keys:
+ - name
+ x-kubernetes-list-type: map
+ configMapInfo:
+ description: the reference for cn configMap.
+ properties:
+ configMapName:
+ description: ConfigMapName mapped the configuration files
+ in the doris 'conf/' directory. such as 'fe.conf', 'be.conf'.
+ If HDFS access is involved, there may also be 'core-site.xml'
+ and other files. doris-operator mounts these configuration
+ files in the '/etc/doris' directory by default. links them
+ to the 'conf/' directory of the doris component through
+ soft links.
+ type: string
+ configMaps:
+ description: ConfigMaps can mount multiple configmaps to the
+ specified path. The mounting path of configmap cannot be
+ repeated.
+ items:
+ properties:
+ configMapName:
+ description: name of configmap that needs to mount.
+ type: string
+ mountPath:
+ description: Current ConfigMap Mount Path. If MountConfigMapInfo
+ belongs to the same ConfigMapInfo, their MountPath
+ cannot be repeated.
+ type: string
+ type: object
+ type: array
+ resolveKey:
+ description: 'Deprecated: This configuration has been abandoned
+ and will be cleared in version 1.7.0. It is currently forced
+ to be ''fe.conf'', ''be.conf'', ''apache_hdfs_broker.conf''
+ It is no longer effective. the configuration content will
+ not take effect.'
+ type: string
+ type: object
+ containerSecurityContext:
+ description: Security context for all containers running in the
+ pod (unless they override it).
+ properties:
+ allowPrivilegeEscalation:
+ description: 'AllowPrivilegeEscalation controls whether a
+ process can gain more privileges than its parent process.
+ This bool directly controls if the no_new_privs flag will
+ be set on the container process. AllowPrivilegeEscalation
+ is true always when the container is: 1) run as Privileged
+ 2) has CAP_SYS_ADMIN Note that this field cannot be set
+ when spec.os.name is windows.'
+ type: boolean
+ capabilities:
+ description: The capabilities to add/drop when running containers.
+ Defaults to the default set of capabilities granted by the
+ container runtime. Note that this field cannot be set when
+ spec.os.name is windows.
+ properties:
+ add:
+ description: Added capabilities
+ items:
+ description: Capability represent POSIX capabilities
+ type
+ type: string
+ type: array
+ drop:
+ description: Removed capabilities
+ items:
+ description: Capability represent POSIX capabilities
+ type
+ type: string
+ type: array
+ type: object
+ privileged:
+ description: Run container in privileged mode. Processes in
+ privileged containers are essentially equivalent to root
+ on the host. Defaults to false. Note that this field cannot
+ be set when spec.os.name is windows.
+ type: boolean
+ procMount:
+ description: procMount denotes the type of proc mount to use
+ for the containers. The default is DefaultProcMount which
+ uses the container runtime defaults for readonly paths and
+ masked paths. This requires the ProcMountType feature flag
+ to be enabled. Note that this field cannot be set when spec.os.name
+ is windows.
+ type: string
+ readOnlyRootFilesystem:
+ description: Whether this container has a read-only root filesystem.
+ Default is false. Note that this field cannot be set when
+ spec.os.name is windows.
+ type: boolean
+ runAsGroup:
+ description: The GID to run the entrypoint of the container
+ process. Uses runtime default if unset. May also be set
+ in PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence. Note that this field cannot be set when
+ spec.os.name is windows.
+ format: int64
+ type: integer
+ runAsNonRoot:
+ description: Indicates that the container must run as a non-root
+ user. If true, the Kubelet will validate the image at runtime
+ to ensure that it does not run as UID 0 (root) and fail
+ to start the container if it does. If unset or false, no
+ such validation will be performed. May also be set in PodSecurityContext. If
+ set in both SecurityContext and PodSecurityContext, the
+ value specified in SecurityContext takes precedence.
+ type: boolean
+ runAsUser:
+ description: The UID to run the entrypoint of the container
+ process. Defaults to user specified in image metadata if
+ unspecified. May also be set in PodSecurityContext. If
+ set in both SecurityContext and PodSecurityContext, the
+ value specified in SecurityContext takes precedence. Note
+ that this field cannot be set when spec.os.name is windows.
+ format: int64
+ type: integer
+ seLinuxOptions:
+ description: The SELinux context to be applied to the container.
+ If unspecified, the container runtime will allocate a random
+ SELinux context for each container. May also be set in
+ PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence. Note that this field cannot be set when
+ spec.os.name is windows.
+ properties:
+ level:
+ description: Level is SELinux level label that applies
+ to the container.
+ type: string
+ role:
+ description: Role is a SELinux role label that applies
+ to the container.
+ type: string
+ type:
+ description: Type is a SELinux type label that applies
+ to the container.
+ type: string
+ user:
+ description: User is a SELinux user label that applies
+ to the container.
+ type: string
+ type: object
+ seccompProfile:
+ description: The seccomp options to use by this container.
+ If seccomp options are provided at both the pod & container
+ level, the container options override the pod options. Note
+ that this field cannot be set when spec.os.name is windows.
+ properties:
+ localhostProfile:
+ description: localhostProfile indicates a profile defined
+ in a file on the node should be used. The profile must
+ be preconfigured on the node to work. Must be a descending
+ path, relative to the kubelet's configured seccomp profile
+ location. Must only be set if type is "Localhost".
+ type: string
+ type:
+ description: "type indicates which kind of seccomp profile
+ will be applied. Valid options are: \n Localhost - a
+ profile defined in a file on the node should be used.
+ RuntimeDefault - the container runtime default profile
+ should be used. Unconfined - no profile should be applied."
+ type: string
+ required:
+ - type
+ type: object
+ windowsOptions:
+ description: The Windows specific settings applied to all
+ containers. If unspecified, the options from the PodSecurityContext
+ will be used. If set in both SecurityContext and PodSecurityContext,
+ the value specified in SecurityContext takes precedence.
+ Note that this field cannot be set when spec.os.name is
+ linux.
+ properties:
+ gmsaCredentialSpec:
+ description: GMSACredentialSpec is where the GMSA admission
+ webhook (https://github.com/kubernetes-sigs/windows-gmsa)
+ inlines the contents of the GMSA credential spec named
+ by the GMSACredentialSpecName field.
+ type: string
+ gmsaCredentialSpecName:
+ description: GMSACredentialSpecName is the name of the
+ GMSA credential spec to use.
+ type: string
+ hostProcess:
+ description: HostProcess determines if a container should
+ be run as a 'Host Process' container. This field is
+ alpha-level and will only be honored by components that
+ enable the WindowsHostProcessContainers feature flag.
+ Setting this field without the feature flag will result
+ in errors when validating the Pod. All of a Pod's containers
+ must have the same effective HostProcess value (it is
+ not allowed to have a mix of HostProcess containers
+ and non-HostProcess containers). In addition, if HostProcess
+ is true then HostNetwork must also be set to true.
+ type: boolean
+ runAsUserName:
+ description: The UserName in Windows to run the entrypoint
+ of the container process. Defaults to the user specified
+ in image metadata if unspecified. May also be set in
+ PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence.
+ type: string
+ type: object
+ type: object
+ envVars:
+ description: cnEnvVars is a slice of environment variables that
+ are added to the pods, the default is empty.
+ items:
+ description: EnvVar represents an environment variable present
+ in a Container.
+ properties:
+ name:
+ description: Name of the environment variable. Must be a
+ C_IDENTIFIER.
+ type: string
+ value:
+ description: 'Variable references $(VAR_NAME) are expanded
+ using the previously defined environment variables in
+ the container and any service environment variables. If
+ a variable cannot be resolved, the reference in the input
+ string will be unchanged. Double $$ are reduced to a single
+ $, which allows for escaping the $(VAR_NAME) syntax: i.e.
+ "$$(VAR_NAME)" will produce the string literal "$(VAR_NAME)".
+ Escaped references will never be expanded, regardless
+ of whether the variable exists or not. Defaults to "".'
+ type: string
+ valueFrom:
+ description: Source for the environment variable's value.
+ Cannot be used if value is not empty.
+ properties:
+ configMapKeyRef:
+ description: Selects a key of a ConfigMap.
+ properties:
+ key:
+ description: The key to select.
+ type: string
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind,
+ uid?'
+ type: string
+ optional:
+ description: Specify whether the ConfigMap or its
+ key must be defined
+ type: boolean
+ required:
+ - key
+ type: object
+ x-kubernetes-map-type: atomic
+ fieldRef:
+ description: 'Selects a field of the pod: supports metadata.name,
+ metadata.namespace, `metadata.labels['''']`,
+ `metadata.annotations['''']`, spec.nodeName,
+ spec.serviceAccountName, status.hostIP, status.podIP,
+ status.podIPs.'
+ properties:
+ apiVersion:
+ description: Version of the schema the FieldPath
+ is written in terms of, defaults to "v1".
+ type: string
+ fieldPath:
+ description: Path of the field to select in the
+ specified API version.
+ type: string
+ required:
+ - fieldPath
+ type: object
+ x-kubernetes-map-type: atomic
+ resourceFieldRef:
+ description: 'Selects a resource of the container: only
+ resources limits and requests (limits.cpu, limits.memory,
+ limits.ephemeral-storage, requests.cpu, requests.memory
+ and requests.ephemeral-storage) are currently supported.'
+ properties:
+ containerName:
+ description: 'Container name: required for volumes,
+ optional for env vars'
+ type: string
+ divisor:
+ anyOf:
+ - type: integer
+ - type: string
+ description: Specifies the output format of the
+ exposed resources, defaults to "1"
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ resource:
+ description: 'Required: resource to select'
+ type: string
+ required:
+ - resource
+ type: object
+ x-kubernetes-map-type: atomic
+ secretKeyRef:
+ description: Selects a key of a secret in the pod's
+ namespace
+ properties:
+ key:
+ description: The key of the secret to select from. Must
+ be a valid secret key.
+ type: string
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind,
+ uid?'
+ type: string
+ optional:
+ description: Specify whether the Secret or its key
+ must be defined
+ type: boolean
+ required:
+ - key
+ type: object
+ x-kubernetes-map-type: atomic
+ type: object
+ required:
+ - name
+ type: object
+ type: array
+ feAddress:
+ description: specify register fe addresses
+ properties:
+ ServiceName:
+ description: the service name that proxy fe on k8s. the service
+ must in same namespace with fe.
+ type: string
+ endpoints:
+ description: the fe addresses if not deploy by crd, user can
+ use k8s deploy fe observer.
+ properties:
+ :address:
+ description: the ip or domain array.
+ items:
+ type: string
+ type: array
+ port:
+ description: the fe port that for query. the field `query_port`
+ defines in fe config.
+ type: integer
+ type: object
+ type: object
+ hostAliases:
+ description: HostAliases is an optional list of hosts and IPs
+ that will be injected into the pod's hosts file if specified.
+ This is only valid for non-hostNetwork pods.
+ items:
+ description: HostAlias holds the mapping between IP and hostnames
+ that will be injected as an entry in the pod's hosts file.
+ properties:
+ hostnames:
+ description: Hostnames for the above IP address.
+ items:
+ type: string
+ type: array
+ ip:
+ description: IP address of the host file entry.
+ type: string
+ type: object
+ type: array
+ image:
+ description: Image for a doris cn deployment.
+ type: string
+ imagePullSecrets:
+ description: 'ImagePullSecrets is an optional list of references
+ to secrets in the same namespace to use for pulling any of the
+ images used by this PodSpec. If specified, these secrets will
+ be passed to individual puller implementations for them to use.
+ More info: https://kubernetes.io/docs/concepts/containers/images#specifying-imagepullsecrets-on-a-pod'
+ items:
+ description: LocalObjectReference contains enough information
+ to let you locate the referenced object inside the same namespace.
+ properties:
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind, uid?'
+ type: string
+ type: object
+ x-kubernetes-map-type: atomic
+ type: array
+ limits:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Limits describes the maximum amount of compute resources
+ allowed. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ nodeSelector:
+ additionalProperties:
+ type: string
+ description: (Optional) If specified, the pod's nodeSelector,displayName="Map
+ of nodeSelectors to match when scheduling pods on nodes"
+ type: object
+ persistentVolumes:
+ items:
+ description: PersistentVolume defines volume information and
+ container mount information.
+ properties:
+ annotations:
+ additionalProperties:
+ type: string
+ description: Annotation for PVC pods. Users can adapt the
+ storage authentication and pv binding of the cloud platform
+ through configuration. It only takes effect in the first
+ configuration and cannot be added or modified later.
+ type: object
+ mountPath:
+ description: the mount path for component service.
+ type: string
+ name:
+ description: the volume name associate with
+ type: string
+ persistentVolumeClaimSpec:
+ description: PersistentVolumeClaimSpec is a list of claim
+ spec about storage that pods are required.
+ properties:
+ accessModes:
+ description: 'accessModes contains the desired access
+ modes the volume should have. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#access-modes-1'
+ items:
+ type: string
+ type: array
+ dataSource:
+ description: 'dataSource field can be used to specify
+ either: * An existing VolumeSnapshot object (snapshot.storage.k8s.io/VolumeSnapshot)
+ * An existing PVC (PersistentVolumeClaim) If the provisioner
+ or an external controller can support the specified
+ data source, it will create a new volume based on
+ the contents of the specified data source. When the
+ AnyVolumeDataSource feature gate is enabled, dataSource
+ contents will be copied to dataSourceRef, and dataSourceRef
+ contents will be copied to dataSource when dataSourceRef.namespace
+ is not specified. If the namespace is specified, then
+ dataSourceRef will not be copied to dataSource.'
+ properties:
+ apiGroup:
+ description: APIGroup is the group for the resource
+ being referenced. If APIGroup is not specified,
+ the specified Kind must be in the core API group.
+ For any other third-party types, APIGroup is required.
+ type: string
+ kind:
+ description: Kind is the type of resource being
+ referenced
+ type: string
+ name:
+ description: Name is the name of resource being
+ referenced
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ x-kubernetes-map-type: atomic
+ dataSourceRef:
+ description: 'dataSourceRef specifies the object from
+ which to populate the volume with data, if a non-empty
+ volume is desired. This may be any object from a non-empty
+ API group (non core object) or a PersistentVolumeClaim
+ object. When this field is specified, volume binding
+ will only succeed if the type of the specified object
+ matches some installed volume populator or dynamic
+ provisioner. This field will replace the functionality
+ of the dataSource field and as such if both fields
+ are non-empty, they must have the same value. For
+ backwards compatibility, when namespace isn''t specified
+ in dataSourceRef, both fields (dataSource and dataSourceRef)
+ will be set to the same value automatically if one
+ of them is empty and the other is non-empty. When
+ namespace is specified in dataSourceRef, dataSource
+ isn''t set to the same value and must be empty. There
+ are three important differences between dataSource
+ and dataSourceRef: * While dataSource only allows
+ two specific types of objects, dataSourceRef allows
+ any non-core object, as well as PersistentVolumeClaim
+ objects. * While dataSource ignores disallowed values
+ (dropping them), dataSourceRef preserves all values,
+ and generates an error if a disallowed value is specified.
+ * While dataSource only allows local objects, dataSourceRef
+ allows objects in any namespaces. (Beta) Using this
+ field requires the AnyVolumeDataSource feature gate
+ to be enabled. (Alpha) Using the namespace field of
+ dataSourceRef requires the CrossNamespaceVolumeDataSource
+ feature gate to be enabled.'
+ properties:
+ apiGroup:
+ description: APIGroup is the group for the resource
+ being referenced. If APIGroup is not specified,
+ the specified Kind must be in the core API group.
+ For any other third-party types, APIGroup is required.
+ type: string
+ kind:
+ description: Kind is the type of resource being
+ referenced
+ type: string
+ name:
+ description: Name is the name of resource being
+ referenced
+ type: string
+ namespace:
+ description: Namespace is the namespace of resource
+ being referenced Note that when a namespace is
+ specified, a gateway.networking.k8s.io/ReferenceGrant
+ object is required in the referent namespace to
+ allow that namespace's owner to accept the reference.
+ See the ReferenceGrant documentation for details.
+ (Alpha) This field requires the CrossNamespaceVolumeDataSource
+ feature gate to be enabled.
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ resources:
+ description: 'resources represents the minimum resources
+ the volume should have. If RecoverVolumeExpansionFailure
+ feature is enabled users are allowed to specify resource
+ requirements that are lower than previous value but
+ must still be higher than capacity recorded in the
+ status field of the claim. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#resources'
+ properties:
+ claims:
+ description: "Claims lists the names of resources,
+ defined in spec.resourceClaims, that are used
+ by this container. \n This is an alpha field and
+ requires enabling the DynamicResourceAllocation
+ feature gate. \n This field is immutable."
+ items:
+ description: ResourceClaim references one entry
+ in PodSpec.ResourceClaims.
+ properties:
+ name:
+ description: Name must match the name of one
+ entry in pod.spec.resourceClaims of the
+ Pod where this field is used. It makes that
+ resource available inside a container.
+ type: string
+ required:
+ - name
+ type: object
+ type: array
+ x-kubernetes-list-map-keys:
+ - name
+ x-kubernetes-list-type: map
+ limits:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Limits describes the maximum amount
+ of compute resources allowed. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ requests:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Requests describes the minimum amount
+ of compute resources required. If Requests is
+ omitted for a container, it defaults to Limits
+ if that is explicitly specified, otherwise to
+ an implementation-defined value. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ type: object
+ selector:
+ description: selector is a label query over volumes
+ to consider for binding.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are ANDed.
+ items:
+ description: A label selector requirement is a
+ selector that contains values, a key, and an
+ operator that relates the key and values.
+ properties:
+ key:
+ description: key is the label key that the
+ selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's relationship
+ to a set of values. Valid operators are
+ In, NotIn, Exists and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty. If the
+ operator is Exists or DoesNotExist, the
+ values array must be empty. This array is
+ replaced during a strategic merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is "In",
+ and the values array contains only "value". The
+ requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ storageClassName:
+ description: 'storageClassName is the name of the StorageClass
+ required by the claim. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#class-1'
+ type: string
+ volumeMode:
+ description: volumeMode defines what type of volume
+ is required by the claim. Value of Filesystem is implied
+ when not included in claim spec.
+ type: string
+ volumeName:
+ description: volumeName is the binding reference to
+ the PersistentVolume backing this claim.
+ type: string
+ type: object
+ provisioner:
+ description: defines pvc provisioner
+ type: string
+ type: object
+ type: array
+ podLabels:
+ additionalProperties:
+ type: string
+ description: podLabels for user selector or classify pods
+ type: object
+ replicas:
+ description: Replicas is the number of desired cn Pod.
+ format: int32
+ minimum: 0
+ type: integer
+ requests:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Requests describes the minimum amount of compute
+ resources required. If Requests is omitted for a container,
+ it defaults to Limits if that is explicitly specified, otherwise
+ to an implementation-defined value. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ securityContext:
+ description: Security context for pod.
+ properties:
+ fsGroup:
+ description: "A special supplemental group that applies to
+ all containers in a pod. Some volume types allow the Kubelet
+ to change the ownership of that volume to be owned by the
+ pod: \n 1. The owning GID will be the FSGroup 2. The setgid
+ bit is set (new files created in the volume will be owned
+ by FSGroup) 3. The permission bits are OR'd with rw-rw----
+ \n If unset, the Kubelet will not modify the ownership and
+ permissions of any volume. Note that this field cannot be
+ set when spec.os.name is windows."
+ format: int64
+ type: integer
+ fsGroupChangePolicy:
+ description: 'fsGroupChangePolicy defines behavior of changing
+ ownership and permission of the volume before being exposed
+ inside Pod. This field will only apply to volume types which
+ support fsGroup based ownership(and permissions). It will
+ have no effect on ephemeral volume types such as: secret,
+ configmaps and emptydir. Valid values are "OnRootMismatch"
+ and "Always". If not specified, "Always" is used. Note that
+ this field cannot be set when spec.os.name is windows.'
+ type: string
+ runAsGroup:
+ description: The GID to run the entrypoint of the container
+ process. Uses runtime default if unset. May also be set
+ in SecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence for that container. Note that this field
+ cannot be set when spec.os.name is windows.
+ format: int64
+ type: integer
+ runAsNonRoot:
+ description: Indicates that the container must run as a non-root
+ user. If true, the Kubelet will validate the image at runtime
+ to ensure that it does not run as UID 0 (root) and fail
+ to start the container if it does. If unset or false, no
+ such validation will be performed. May also be set in SecurityContext. If
+ set in both SecurityContext and PodSecurityContext, the
+ value specified in SecurityContext takes precedence.
+ type: boolean
+ runAsUser:
+ description: The UID to run the entrypoint of the container
+ process. Defaults to user specified in image metadata if
+ unspecified. May also be set in SecurityContext. If set
+ in both SecurityContext and PodSecurityContext, the value
+ specified in SecurityContext takes precedence for that container.
+ Note that this field cannot be set when spec.os.name is
+ windows.
+ format: int64
+ type: integer
+ seLinuxOptions:
+ description: The SELinux context to be applied to all containers.
+ If unspecified, the container runtime will allocate a random
+ SELinux context for each container. May also be set in
+ SecurityContext. If set in both SecurityContext and PodSecurityContext,
+ the value specified in SecurityContext takes precedence
+ for that container. Note that this field cannot be set when
+ spec.os.name is windows.
+ properties:
+ level:
+ description: Level is SELinux level label that applies
+ to the container.
+ type: string
+ role:
+ description: Role is a SELinux role label that applies
+ to the container.
+ type: string
+ type:
+ description: Type is a SELinux type label that applies
+ to the container.
+ type: string
+ user:
+ description: User is a SELinux user label that applies
+ to the container.
+ type: string
+ type: object
+ seccompProfile:
+ description: The seccomp options to use by the containers
+ in this pod. Note that this field cannot be set when spec.os.name
+ is windows.
+ properties:
+ localhostProfile:
+ description: localhostProfile indicates a profile defined
+ in a file on the node should be used. The profile must
+ be preconfigured on the node to work. Must be a descending
+ path, relative to the kubelet's configured seccomp profile
+ location. Must only be set if type is "Localhost".
+ type: string
+ type:
+ description: "type indicates which kind of seccomp profile
+ will be applied. Valid options are: \n Localhost - a
+ profile defined in a file on the node should be used.
+ RuntimeDefault - the container runtime default profile
+ should be used. Unconfined - no profile should be applied."
+ type: string
+ required:
+ - type
+ type: object
+ supplementalGroups:
+ items:
+ format: int64
+ type: integer
+ type: array
+ sysctls:
+ description: Sysctls hold a list of namespaced sysctls used
+ for the pod. Pods with unsupported sysctls (by the container
+ runtime) might fail to launch. Note that this field cannot
+ be set when spec.os.name is windows.
+ items:
+ description: Sysctl defines a kernel parameter to be set
+ properties:
+ name:
+ description: Name of a property to set
+ type: string
+ value:
+ description: Value of a property to set
+ type: string
+ required:
+ - name
+ - value
+ type: object
+ type: array
+ windowsOptions:
+ description: The Windows specific settings applied to all
+ containers. If unspecified, the options within a container's
+ SecurityContext will be used. If set in both SecurityContext
+ and PodSecurityContext, the value specified in SecurityContext
+ takes precedence. Note that this field cannot be set when
+ spec.os.name is linux.
+ properties:
+ gmsaCredentialSpec:
+ description: GMSACredentialSpec is where the GMSA admission
+ webhook (https://github.com/kubernetes-sigs/windows-gmsa)
+ inlines the contents of the GMSA credential spec named
+ by the GMSACredentialSpecName field.
+ type: string
+ gmsaCredentialSpecName:
+ description: GMSACredentialSpecName is the name of the
+ GMSA credential spec to use.
+ type: string
+ hostProcess:
+ description: HostProcess determines if a container should
+ be run as a 'Host Process' container. This field is
+ alpha-level and will only be honored by components that
+ enable the WindowsHostProcessContainers feature flag.
+ Setting this field without the feature flag will result
+ in errors when validating the Pod. All of a Pod's containers
+ must have the same effective HostProcess value (it is
+ not allowed to have a mix of HostProcess containers
+ and non-HostProcess containers). In addition, if HostProcess
+ is true then HostNetwork must also be set to true.
+ type: boolean
+ runAsUserName:
+ description: The UserName in Windows to run the entrypoint
+ of the container process. Defaults to the user specified
+ in image metadata if unspecified. May also be set in
+ PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence.
+ type: string
+ type: object
+ type: object
+ service:
+ description: 'expose doris components for accessing. example:
+ if you want to use `stream load` to load data into doris out
+ k8s, you can use be service and config different service type
+ for loading data.'
+ properties:
+ annotations:
+ additionalProperties:
+ type: string
+ description: Annotations for using function on different cloud
+ platform.
+ type: object
+ loadBalancerIP:
+ description: 'Only applies to Service Type: LoadBalancer.
+ This feature depends on whether the underlying cloud-provider
+ supports specifying the loadBalancerIP when a load balancer
+ is created. This field will be ignored if the cloud-provider
+ does not support the feature. This field was under-specified
+ and its meaning varies across implementations, and it cannot
+ support dual-stack. As of Kubernetes v1.24, users are encouraged
+ to use implementation-specific annotations when available.
+ This field may be removed in a future API version.'
+ type: string
+ servicePorts:
+ description: ServicePort config service for NodePort access
+ mode.
+ items:
+ description: DorisServicePort for ServiceType=NodePort situation.
+ properties:
+ nodePort:
+ description: 'The port on each node on which this service
+ is exposed when type is NodePort or LoadBalancer. Usually
+ assigned by the system. If a value is specified, in-range,
+ and not in use it will be used, otherwise the operation
+ will fail. If not specified, a port will be allocated
+ if this Service requires one. If this field is specified
+ when creating a Service which does not need it, creation
+ will fail. This field will be wiped when updating
+ a Service to no longer need it (e.g. changing type
+ from NodePort to ClusterIP). More info: https://kubernetes.io/docs/concepts/services-networking/service/#type-nodeport
+ need in 30000-32767'
+ format: int32
+ type: integer
+ targetPort:
+ description: 'Number or name of the port to access on
+ the pods targeted by the service. Number must be in
+ the range 1 to 65535. Name must be an IANA_SVC_NAME.
+ If this is a string, it will be looked up as a named
+ port in the target Pod''s container ports. If this
+ is not specified, the value of the ''port'' field
+ is used (an identity map). This field is ignored for
+ services with clusterIP=None, and should be omitted
+ or set equal to the ''port'' field. More info: https://kubernetes.io/docs/concepts/services-networking/service/#defining-a-service'
+ format: int32
+ type: integer
+ type: object
+ type: array
+ type:
+ description: 'type of service,the possible value for the service
+ type are : ClusterIP, NodePort, LoadBalancer,ExternalName.
+ More info: https://kubernetes.io/docs/concepts/services-networking/service/#publishing-services-service-types'
+ type: string
+ type: object
+ serviceAccount:
+ description: serviceAccount for cn access cloud service.
+ type: string
+ systemInitialization:
+ description: SystemInitialization for fe, be and cn setting system
+ parameters.
+ properties:
+ args:
+ description: Arguments to the entrypoint.
+ items:
+ type: string
+ type: array
+ command:
+ description: Entrypoint array. Not executed within a shell.
+ items:
+ type: string
+ type: array
+ initImage:
+ description: Image for doris initialization, default is selectdb/alpine:latest.
+ type: string
+ type: object
+ tolerations:
+ description: (Optional) Tolerations for scheduling pods onto some
+ dedicated nodes
+ items:
+ description: The pod this Toleration is attached to tolerates
+ any taint that matches the triple using
+ the matching operator .
+ properties:
+ effect:
+ description: Effect indicates the taint effect to match.
+ Empty means match all taint effects. When specified, allowed
+ values are NoSchedule, PreferNoSchedule and NoExecute.
+ type: string
+ key:
+ description: Key is the taint key that the toleration applies
+ to. Empty means match all taint keys. If the key is empty,
+ operator must be Exists; this combination means to match
+ all values and all keys.
+ type: string
+ operator:
+ description: Operator represents a key's relationship to
+ the value. Valid operators are Exists and Equal. Defaults
+ to Equal. Exists is equivalent to wildcard for value,
+ so that a pod can tolerate all taints of a particular
+ category.
+ type: string
+ tolerationSeconds:
+ description: TolerationSeconds represents the period of
+ time the toleration (which must be of effect NoExecute,
+ otherwise this field is ignored) tolerates the taint.
+ By default, it is not set, which means tolerate the taint
+ forever (do not evict). Zero and negative values will
+ be treated as 0 (evict immediately) by the system.
+ format: int64
+ type: integer
+ value:
+ description: Value is the taint value the toleration matches
+ to. If the operator is Exists, the value should be empty,
+ otherwise just a regular string.
+ type: string
+ type: object
+ type: array
+ required:
+ - image
+ type: object
+ brokerSpec:
+ description: defines the broker state that will be created by operator.
+ properties:
+ affinity:
+ description: If specified, the pod's scheduling constraints.
+ properties:
+ nodeAffinity:
+ description: Describes node affinity scheduling rules for
+ the pod.
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ description: The scheduler will prefer to schedule pods
+ to nodes that satisfy the affinity expressions specified
+ by this field, but it may choose a node that violates
+ one or more of the expressions. The node that is most
+ preferred is the one with the greatest sum of weights,
+ i.e. for each node that meets all of the scheduling
+ requirements (resource request, requiredDuringScheduling
+ affinity expressions, etc.), compute a sum by iterating
+ through the elements of this field and adding "weight"
+ to the sum if the node matches the corresponding matchExpressions;
+ the node(s) with the highest sum are the most preferred.
+ items:
+ description: An empty preferred scheduling term matches
+ all objects with implicit weight 0 (i.e. it's a no-op).
+ A null preferred scheduling term matches no objects
+ (i.e. is also a no-op).
+ properties:
+ preference:
+ description: A node selector term, associated with
+ the corresponding weight.
+ properties:
+ matchExpressions:
+ description: A list of node selector requirements
+ by node's labels.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchFields:
+ description: A list of node selector requirements
+ by node's fields.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ type: object
+ x-kubernetes-map-type: atomic
+ weight:
+ description: Weight associated with matching the
+ corresponding nodeSelectorTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - preference
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ description: If the affinity requirements specified by
+ this field are not met at scheduling time, the pod will
+ not be scheduled onto the node. If the affinity requirements
+ specified by this field cease to be met at some point
+ during pod execution (e.g. due to an update), the system
+ may or may not try to eventually evict the pod from
+ its node.
+ properties:
+ nodeSelectorTerms:
+ description: Required. A list of node selector terms.
+ The terms are ORed.
+ items:
+ description: A null or empty node selector term
+ matches no objects. The requirements of them are
+ ANDed. The TopologySelectorTerm type implements
+ a subset of the NodeSelectorTerm.
+ properties:
+ matchExpressions:
+ description: A list of node selector requirements
+ by node's labels.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchFields:
+ description: A list of node selector requirements
+ by node's fields.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ type: object
+ x-kubernetes-map-type: atomic
+ type: array
+ required:
+ - nodeSelectorTerms
+ type: object
+ x-kubernetes-map-type: atomic
+ type: object
+ podAffinity:
+ description: Describes pod affinity scheduling rules (e.g.
+ co-locate this pod in the same node, zone, etc. as some
+ other pod(s)).
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ description: The scheduler will prefer to schedule pods
+ to nodes that satisfy the affinity expressions specified
+ by this field, but it may choose a node that violates
+ one or more of the expressions. The node that is most
+ preferred is the one with the greatest sum of weights,
+ i.e. for each node that meets all of the scheduling
+ requirements (resource request, requiredDuringScheduling
+ affinity expressions, etc.), compute a sum by iterating
+ through the elements of this field and adding "weight"
+ to the sum if the node has pods which matches the corresponding
+ podAffinityTerm; the node(s) with the highest sum are
+ the most preferred.
+ items:
+ description: The weights of all of the matched WeightedPodAffinityTerm
+ fields are added per-node to find the most preferred
+ node(s)
+ properties:
+ podAffinityTerm:
+ description: Required. A pod affinity term, associated
+ with the corresponding weight.
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by
+ this field and the ones listed in the namespaces
+ field. null selector and null or empty namespaces
+ list means "this pod's namespace". An empty
+ selector ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to.
+ The term is applied to the union of the namespaces
+ listed in this field and the ones selected
+ by namespaceSelector. null or empty namespaces
+ list and null namespaceSelector means "this
+ pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the
+ pods matching the labelSelector in the specified
+ namespaces, where co-located is defined as
+ running on a node whose value of the label
+ with key topologyKey matches that of any node
+ on which any of the selected pods is running.
+ Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ weight:
+ description: weight associated with matching the
+ corresponding podAffinityTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - podAffinityTerm
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ description: If the affinity requirements specified by
+ this field are not met at scheduling time, the pod will
+ not be scheduled onto the node. If the affinity requirements
+ specified by this field cease to be met at some point
+ during pod execution (e.g. due to a pod label update),
+ the system may or may not try to eventually evict the
+ pod from its node. When there are multiple elements,
+ the lists of nodes corresponding to each podAffinityTerm
+ are intersected, i.e. all terms must be satisfied.
+ items:
+ description: Defines a set of pods (namely those matching
+ the labelSelector relative to the given namespace(s))
+ that this pod should be co-located (affinity) or not
+ co-located (anti-affinity) with, where co-located
+ is defined as running on a node whose value of the
+ label with key matches that of any node
+ on which a pod of the set of pods is running
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by this
+ field and the ones listed in the namespaces field.
+ null selector and null or empty namespaces list
+ means "this pod's namespace". An empty selector
+ ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to. The
+ term is applied to the union of the namespaces
+ listed in this field and the ones selected by
+ namespaceSelector. null or empty namespaces list
+ and null namespaceSelector means "this pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the pods
+ matching the labelSelector in the specified namespaces,
+ where co-located is defined as running on a node
+ whose value of the label with key topologyKey
+ matches that of any node on which any of the selected
+ pods is running. Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ type: array
+ type: object
+ podAntiAffinity:
+ description: Describes pod anti-affinity scheduling rules
+ (e.g. avoid putting this pod in the same node, zone, etc.
+ as some other pod(s)).
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ description: The scheduler will prefer to schedule pods
+ to nodes that satisfy the anti-affinity expressions
+ specified by this field, but it may choose a node that
+ violates one or more of the expressions. The node that
+ is most preferred is the one with the greatest sum of
+ weights, i.e. for each node that meets all of the scheduling
+ requirements (resource request, requiredDuringScheduling
+ anti-affinity expressions, etc.), compute a sum by iterating
+ through the elements of this field and adding "weight"
+ to the sum if the node has pods which matches the corresponding
+ podAffinityTerm; the node(s) with the highest sum are
+ the most preferred.
+ items:
+ description: The weights of all of the matched WeightedPodAffinityTerm
+ fields are added per-node to find the most preferred
+ node(s)
+ properties:
+ podAffinityTerm:
+ description: Required. A pod affinity term, associated
+ with the corresponding weight.
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by
+ this field and the ones listed in the namespaces
+ field. null selector and null or empty namespaces
+ list means "this pod's namespace". An empty
+ selector ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to.
+ The term is applied to the union of the namespaces
+ listed in this field and the ones selected
+ by namespaceSelector. null or empty namespaces
+ list and null namespaceSelector means "this
+ pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the
+ pods matching the labelSelector in the specified
+ namespaces, where co-located is defined as
+ running on a node whose value of the label
+ with key topologyKey matches that of any node
+ on which any of the selected pods is running.
+ Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ weight:
+ description: weight associated with matching the
+ corresponding podAffinityTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - podAffinityTerm
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ description: If the anti-affinity requirements specified
+ by this field are not met at scheduling time, the pod
+ will not be scheduled onto the node. If the anti-affinity
+ requirements specified by this field cease to be met
+ at some point during pod execution (e.g. due to a pod
+ label update), the system may or may not try to eventually
+ evict the pod from its node. When there are multiple
+ elements, the lists of nodes corresponding to each podAffinityTerm
+ are intersected, i.e. all terms must be satisfied.
+ items:
+ description: Defines a set of pods (namely those matching
+ the labelSelector relative to the given namespace(s))
+ that this pod should be co-located (affinity) or not
+ co-located (anti-affinity) with, where co-located
+ is defined as running on a node whose value of the
+ label with key matches that of any node
+ on which a pod of the set of pods is running
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by this
+ field and the ones listed in the namespaces field.
+ null selector and null or empty namespaces list
+ means "this pod's namespace". An empty selector
+ ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to. The
+ term is applied to the union of the namespaces
+ listed in this field and the ones selected by
+ namespaceSelector. null or empty namespaces list
+ and null namespaceSelector means "this pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the pods
+ matching the labelSelector in the specified namespaces,
+ where co-located is defined as running on a node
+ whose value of the label with key topologyKey
+ matches that of any node on which any of the selected
+ pods is running. Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ type: array
+ type: object
+ type: object
+ annotations:
+ additionalProperties:
+ type: string
+ description: annotation for fe pods. user can config monitor annotation
+ for collect to monitor system.
+ type: object
+ claims:
+ description: "Claims lists the names of resources, defined in
+ spec.resourceClaims, that are used by this container. \n This
+ is an alpha field and requires enabling the DynamicResourceAllocation
+ feature gate. \n This field is immutable."
+ items:
+ description: ResourceClaim references one entry in PodSpec.ResourceClaims.
+ properties:
+ name:
+ description: Name must match the name of one entry in pod.spec.resourceClaims
+ of the Pod where this field is used. It makes that resource
+ available inside a container.
+ type: string
+ required:
+ - name
+ type: object
+ type: array
+ x-kubernetes-list-map-keys:
+ - name
+ x-kubernetes-list-type: map
+ configMapInfo:
+ description: the reference for cn configMap.
+ properties:
+ configMapName:
+ description: ConfigMapName mapped the configuration files
+ in the doris 'conf/' directory. such as 'fe.conf', 'be.conf'.
+ If HDFS access is involved, there may also be 'core-site.xml'
+ and other files. doris-operator mounts these configuration
+ files in the '/etc/doris' directory by default. links them
+ to the 'conf/' directory of the doris component through
+ soft links.
+ type: string
+ configMaps:
+ description: ConfigMaps can mount multiple configmaps to the
+ specified path. The mounting path of configmap cannot be
+ repeated.
+ items:
+ properties:
+ configMapName:
+ description: name of configmap that needs to mount.
+ type: string
+ mountPath:
+ description: Current ConfigMap Mount Path. If MountConfigMapInfo
+ belongs to the same ConfigMapInfo, their MountPath
+ cannot be repeated.
+ type: string
+ type: object
+ type: array
+ resolveKey:
+ description: 'Deprecated: This configuration has been abandoned
+ and will be cleared in version 1.7.0. It is currently forced
+ to be ''fe.conf'', ''be.conf'', ''apache_hdfs_broker.conf''
+ It is no longer effective. the configuration content will
+ not take effect.'
+ type: string
+ type: object
+ containerSecurityContext:
+ description: Security context for all containers running in the
+ pod (unless they override it).
+ properties:
+ allowPrivilegeEscalation:
+ description: 'AllowPrivilegeEscalation controls whether a
+ process can gain more privileges than its parent process.
+ This bool directly controls if the no_new_privs flag will
+ be set on the container process. AllowPrivilegeEscalation
+ is true always when the container is: 1) run as Privileged
+ 2) has CAP_SYS_ADMIN Note that this field cannot be set
+ when spec.os.name is windows.'
+ type: boolean
+ capabilities:
+ description: The capabilities to add/drop when running containers.
+ Defaults to the default set of capabilities granted by the
+ container runtime. Note that this field cannot be set when
+ spec.os.name is windows.
+ properties:
+ add:
+ description: Added capabilities
+ items:
+ description: Capability represent POSIX capabilities
+ type
+ type: string
+ type: array
+ drop:
+ description: Removed capabilities
+ items:
+ description: Capability represent POSIX capabilities
+ type
+ type: string
+ type: array
+ type: object
+ privileged:
+ description: Run container in privileged mode. Processes in
+ privileged containers are essentially equivalent to root
+ on the host. Defaults to false. Note that this field cannot
+ be set when spec.os.name is windows.
+ type: boolean
+ procMount:
+ description: procMount denotes the type of proc mount to use
+ for the containers. The default is DefaultProcMount which
+ uses the container runtime defaults for readonly paths and
+ masked paths. This requires the ProcMountType feature flag
+ to be enabled. Note that this field cannot be set when spec.os.name
+ is windows.
+ type: string
+ readOnlyRootFilesystem:
+ description: Whether this container has a read-only root filesystem.
+ Default is false. Note that this field cannot be set when
+ spec.os.name is windows.
+ type: boolean
+ runAsGroup:
+ description: The GID to run the entrypoint of the container
+ process. Uses runtime default if unset. May also be set
+ in PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence. Note that this field cannot be set when
+ spec.os.name is windows.
+ format: int64
+ type: integer
+ runAsNonRoot:
+ description: Indicates that the container must run as a non-root
+ user. If true, the Kubelet will validate the image at runtime
+ to ensure that it does not run as UID 0 (root) and fail
+ to start the container if it does. If unset or false, no
+ such validation will be performed. May also be set in PodSecurityContext. If
+ set in both SecurityContext and PodSecurityContext, the
+ value specified in SecurityContext takes precedence.
+ type: boolean
+ runAsUser:
+ description: The UID to run the entrypoint of the container
+ process. Defaults to user specified in image metadata if
+ unspecified. May also be set in PodSecurityContext. If
+ set in both SecurityContext and PodSecurityContext, the
+ value specified in SecurityContext takes precedence. Note
+ that this field cannot be set when spec.os.name is windows.
+ format: int64
+ type: integer
+ seLinuxOptions:
+ description: The SELinux context to be applied to the container.
+ If unspecified, the container runtime will allocate a random
+ SELinux context for each container. May also be set in
+ PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence. Note that this field cannot be set when
+ spec.os.name is windows.
+ properties:
+ level:
+ description: Level is SELinux level label that applies
+ to the container.
+ type: string
+ role:
+ description: Role is a SELinux role label that applies
+ to the container.
+ type: string
+ type:
+ description: Type is a SELinux type label that applies
+ to the container.
+ type: string
+ user:
+ description: User is a SELinux user label that applies
+ to the container.
+ type: string
+ type: object
+ seccompProfile:
+ description: The seccomp options to use by this container.
+ If seccomp options are provided at both the pod & container
+ level, the container options override the pod options. Note
+ that this field cannot be set when spec.os.name is windows.
+ properties:
+ localhostProfile:
+ description: localhostProfile indicates a profile defined
+ in a file on the node should be used. The profile must
+ be preconfigured on the node to work. Must be a descending
+ path, relative to the kubelet's configured seccomp profile
+ location. Must only be set if type is "Localhost".
+ type: string
+ type:
+ description: "type indicates which kind of seccomp profile
+ will be applied. Valid options are: \n Localhost - a
+ profile defined in a file on the node should be used.
+ RuntimeDefault - the container runtime default profile
+ should be used. Unconfined - no profile should be applied."
+ type: string
+ required:
+ - type
+ type: object
+ windowsOptions:
+ description: The Windows specific settings applied to all
+ containers. If unspecified, the options from the PodSecurityContext
+ will be used. If set in both SecurityContext and PodSecurityContext,
+ the value specified in SecurityContext takes precedence.
+ Note that this field cannot be set when spec.os.name is
+ linux.
+ properties:
+ gmsaCredentialSpec:
+ description: GMSACredentialSpec is where the GMSA admission
+ webhook (https://github.com/kubernetes-sigs/windows-gmsa)
+ inlines the contents of the GMSA credential spec named
+ by the GMSACredentialSpecName field.
+ type: string
+ gmsaCredentialSpecName:
+ description: GMSACredentialSpecName is the name of the
+ GMSA credential spec to use.
+ type: string
+ hostProcess:
+ description: HostProcess determines if a container should
+ be run as a 'Host Process' container. This field is
+ alpha-level and will only be honored by components that
+ enable the WindowsHostProcessContainers feature flag.
+ Setting this field without the feature flag will result
+ in errors when validating the Pod. All of a Pod's containers
+ must have the same effective HostProcess value (it is
+ not allowed to have a mix of HostProcess containers
+ and non-HostProcess containers). In addition, if HostProcess
+ is true then HostNetwork must also be set to true.
+ type: boolean
+ runAsUserName:
+ description: The UserName in Windows to run the entrypoint
+ of the container process. Defaults to the user specified
+ in image metadata if unspecified. May also be set in
+ PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence.
+ type: string
+ type: object
+ type: object
+ envVars:
+ description: cnEnvVars is a slice of environment variables that
+ are added to the pods, the default is empty.
+ items:
+ description: EnvVar represents an environment variable present
+ in a Container.
+ properties:
+ name:
+ description: Name of the environment variable. Must be a
+ C_IDENTIFIER.
+ type: string
+ value:
+ description: 'Variable references $(VAR_NAME) are expanded
+ using the previously defined environment variables in
+ the container and any service environment variables. If
+ a variable cannot be resolved, the reference in the input
+ string will be unchanged. Double $$ are reduced to a single
+ $, which allows for escaping the $(VAR_NAME) syntax: i.e.
+ "$$(VAR_NAME)" will produce the string literal "$(VAR_NAME)".
+ Escaped references will never be expanded, regardless
+ of whether the variable exists or not. Defaults to "".'
+ type: string
+ valueFrom:
+ description: Source for the environment variable's value.
+ Cannot be used if value is not empty.
+ properties:
+ configMapKeyRef:
+ description: Selects a key of a ConfigMap.
+ properties:
+ key:
+ description: The key to select.
+ type: string
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind,
+ uid?'
+ type: string
+ optional:
+ description: Specify whether the ConfigMap or its
+ key must be defined
+ type: boolean
+ required:
+ - key
+ type: object
+ x-kubernetes-map-type: atomic
+ fieldRef:
+ description: 'Selects a field of the pod: supports metadata.name,
+ metadata.namespace, `metadata.labels['''']`,
+ `metadata.annotations['''']`, spec.nodeName,
+ spec.serviceAccountName, status.hostIP, status.podIP,
+ status.podIPs.'
+ properties:
+ apiVersion:
+ description: Version of the schema the FieldPath
+ is written in terms of, defaults to "v1".
+ type: string
+ fieldPath:
+ description: Path of the field to select in the
+ specified API version.
+ type: string
+ required:
+ - fieldPath
+ type: object
+ x-kubernetes-map-type: atomic
+ resourceFieldRef:
+ description: 'Selects a resource of the container: only
+ resources limits and requests (limits.cpu, limits.memory,
+ limits.ephemeral-storage, requests.cpu, requests.memory
+ and requests.ephemeral-storage) are currently supported.'
+ properties:
+ containerName:
+ description: 'Container name: required for volumes,
+ optional for env vars'
+ type: string
+ divisor:
+ anyOf:
+ - type: integer
+ - type: string
+ description: Specifies the output format of the
+ exposed resources, defaults to "1"
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ resource:
+ description: 'Required: resource to select'
+ type: string
+ required:
+ - resource
+ type: object
+ x-kubernetes-map-type: atomic
+ secretKeyRef:
+ description: Selects a key of a secret in the pod's
+ namespace
+ properties:
+ key:
+ description: The key of the secret to select from. Must
+ be a valid secret key.
+ type: string
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind,
+ uid?'
+ type: string
+ optional:
+ description: Specify whether the Secret or its key
+ must be defined
+ type: boolean
+ required:
+ - key
+ type: object
+ x-kubernetes-map-type: atomic
+ type: object
+ required:
+ - name
+ type: object
+ type: array
+ feAddress:
+ description: specify register fe addresses
+ properties:
+ ServiceName:
+ description: the service name that proxy fe on k8s. the service
+ must in same namespace with fe.
+ type: string
+ endpoints:
+ description: the fe addresses if not deploy by crd, user can
+ use k8s deploy fe observer.
+ properties:
+ :address:
+ description: the ip or domain array.
+ items:
+ type: string
+ type: array
+ port:
+ description: the fe port that for query. the field `query_port`
+ defines in fe config.
+ type: integer
+ type: object
+ type: object
+ hostAliases:
+ description: HostAliases is an optional list of hosts and IPs
+ that will be injected into the pod's hosts file if specified.
+ This is only valid for non-hostNetwork pods.
+ items:
+ description: HostAlias holds the mapping between IP and hostnames
+ that will be injected as an entry in the pod's hosts file.
+ properties:
+ hostnames:
+ description: Hostnames for the above IP address.
+ items:
+ type: string
+ type: array
+ ip:
+ description: IP address of the host file entry.
+ type: string
+ type: object
+ type: array
+ image:
+ description: Image for a doris cn deployment.
+ type: string
+ imagePullSecrets:
+ description: 'ImagePullSecrets is an optional list of references
+ to secrets in the same namespace to use for pulling any of the
+ images used by this PodSpec. If specified, these secrets will
+ be passed to individual puller implementations for them to use.
+ More info: https://kubernetes.io/docs/concepts/containers/images#specifying-imagepullsecrets-on-a-pod'
+ items:
+ description: LocalObjectReference contains enough information
+ to let you locate the referenced object inside the same namespace.
+ properties:
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind, uid?'
+ type: string
+ type: object
+ x-kubernetes-map-type: atomic
+ type: array
+ kickOffAffinityBe:
+ description: enable affinity with be , if kickoff affinity, the
+ operator will set affinity on broker with be. The affinity is
+ preferred not required. When the user custom affinity the switch
+ does not take effect anymore.
+ type: boolean
+ limits:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Limits describes the maximum amount of compute resources
+ allowed. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ nodeSelector:
+ additionalProperties:
+ type: string
+ description: (Optional) If specified, the pod's nodeSelector,displayName="Map
+ of nodeSelectors to match when scheduling pods on nodes"
+ type: object
+ persistentVolumes:
+ items:
+ description: PersistentVolume defines volume information and
+ container mount information.
+ properties:
+ annotations:
+ additionalProperties:
+ type: string
+ description: Annotation for PVC pods. Users can adapt the
+ storage authentication and pv binding of the cloud platform
+ through configuration. It only takes effect in the first
+ configuration and cannot be added or modified later.
+ type: object
+ mountPath:
+ description: the mount path for component service.
+ type: string
+ name:
+ description: the volume name associate with
+ type: string
+ persistentVolumeClaimSpec:
+ description: PersistentVolumeClaimSpec is a list of claim
+ spec about storage that pods are required.
+ properties:
+ accessModes:
+ description: 'accessModes contains the desired access
+ modes the volume should have. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#access-modes-1'
+ items:
+ type: string
+ type: array
+ dataSource:
+ description: 'dataSource field can be used to specify
+ either: * An existing VolumeSnapshot object (snapshot.storage.k8s.io/VolumeSnapshot)
+ * An existing PVC (PersistentVolumeClaim) If the provisioner
+ or an external controller can support the specified
+ data source, it will create a new volume based on
+ the contents of the specified data source. When the
+ AnyVolumeDataSource feature gate is enabled, dataSource
+ contents will be copied to dataSourceRef, and dataSourceRef
+ contents will be copied to dataSource when dataSourceRef.namespace
+ is not specified. If the namespace is specified, then
+ dataSourceRef will not be copied to dataSource.'
+ properties:
+ apiGroup:
+ description: APIGroup is the group for the resource
+ being referenced. If APIGroup is not specified,
+ the specified Kind must be in the core API group.
+ For any other third-party types, APIGroup is required.
+ type: string
+ kind:
+ description: Kind is the type of resource being
+ referenced
+ type: string
+ name:
+ description: Name is the name of resource being
+ referenced
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ x-kubernetes-map-type: atomic
+ dataSourceRef:
+ description: 'dataSourceRef specifies the object from
+ which to populate the volume with data, if a non-empty
+ volume is desired. This may be any object from a non-empty
+ API group (non core object) or a PersistentVolumeClaim
+ object. When this field is specified, volume binding
+ will only succeed if the type of the specified object
+ matches some installed volume populator or dynamic
+ provisioner. This field will replace the functionality
+ of the dataSource field and as such if both fields
+ are non-empty, they must have the same value. For
+ backwards compatibility, when namespace isn''t specified
+ in dataSourceRef, both fields (dataSource and dataSourceRef)
+ will be set to the same value automatically if one
+ of them is empty and the other is non-empty. When
+ namespace is specified in dataSourceRef, dataSource
+ isn''t set to the same value and must be empty. There
+ are three important differences between dataSource
+ and dataSourceRef: * While dataSource only allows
+ two specific types of objects, dataSourceRef allows
+ any non-core object, as well as PersistentVolumeClaim
+ objects. * While dataSource ignores disallowed values
+ (dropping them), dataSourceRef preserves all values,
+ and generates an error if a disallowed value is specified.
+ * While dataSource only allows local objects, dataSourceRef
+ allows objects in any namespaces. (Beta) Using this
+ field requires the AnyVolumeDataSource feature gate
+ to be enabled. (Alpha) Using the namespace field of
+ dataSourceRef requires the CrossNamespaceVolumeDataSource
+ feature gate to be enabled.'
+ properties:
+ apiGroup:
+ description: APIGroup is the group for the resource
+ being referenced. If APIGroup is not specified,
+ the specified Kind must be in the core API group.
+ For any other third-party types, APIGroup is required.
+ type: string
+ kind:
+ description: Kind is the type of resource being
+ referenced
+ type: string
+ name:
+ description: Name is the name of resource being
+ referenced
+ type: string
+ namespace:
+ description: Namespace is the namespace of resource
+ being referenced Note that when a namespace is
+ specified, a gateway.networking.k8s.io/ReferenceGrant
+ object is required in the referent namespace to
+ allow that namespace's owner to accept the reference.
+ See the ReferenceGrant documentation for details.
+ (Alpha) This field requires the CrossNamespaceVolumeDataSource
+ feature gate to be enabled.
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ resources:
+ description: 'resources represents the minimum resources
+ the volume should have. If RecoverVolumeExpansionFailure
+ feature is enabled users are allowed to specify resource
+ requirements that are lower than previous value but
+ must still be higher than capacity recorded in the
+ status field of the claim. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#resources'
+ properties:
+ claims:
+ description: "Claims lists the names of resources,
+ defined in spec.resourceClaims, that are used
+ by this container. \n This is an alpha field and
+ requires enabling the DynamicResourceAllocation
+ feature gate. \n This field is immutable."
+ items:
+ description: ResourceClaim references one entry
+ in PodSpec.ResourceClaims.
+ properties:
+ name:
+ description: Name must match the name of one
+ entry in pod.spec.resourceClaims of the
+ Pod where this field is used. It makes that
+ resource available inside a container.
+ type: string
+ required:
+ - name
+ type: object
+ type: array
+ x-kubernetes-list-map-keys:
+ - name
+ x-kubernetes-list-type: map
+ limits:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Limits describes the maximum amount
+ of compute resources allowed. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ requests:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Requests describes the minimum amount
+ of compute resources required. If Requests is
+ omitted for a container, it defaults to Limits
+ if that is explicitly specified, otherwise to
+ an implementation-defined value. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ type: object
+ selector:
+ description: selector is a label query over volumes
+ to consider for binding.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are ANDed.
+ items:
+ description: A label selector requirement is a
+ selector that contains values, a key, and an
+ operator that relates the key and values.
+ properties:
+ key:
+ description: key is the label key that the
+ selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's relationship
+ to a set of values. Valid operators are
+ In, NotIn, Exists and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty. If the
+ operator is Exists or DoesNotExist, the
+ values array must be empty. This array is
+ replaced during a strategic merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is "In",
+ and the values array contains only "value". The
+ requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ storageClassName:
+ description: 'storageClassName is the name of the StorageClass
+ required by the claim. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#class-1'
+ type: string
+ volumeMode:
+ description: volumeMode defines what type of volume
+ is required by the claim. Value of Filesystem is implied
+ when not included in claim spec.
+ type: string
+ volumeName:
+ description: volumeName is the binding reference to
+ the PersistentVolume backing this claim.
+ type: string
+ type: object
+ provisioner:
+ description: defines pvc provisioner
+ type: string
+ type: object
+ type: array
+ podLabels:
+ additionalProperties:
+ type: string
+ description: podLabels for user selector or classify pods
+ type: object
+ replicas:
+ description: Replicas is the number of desired cn Pod.
+ format: int32
+ minimum: 0
+ type: integer
+ requests:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Requests describes the minimum amount of compute
+ resources required. If Requests is omitted for a container,
+ it defaults to Limits if that is explicitly specified, otherwise
+ to an implementation-defined value. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ securityContext:
+ description: Security context for pod.
+ properties:
+ fsGroup:
+ description: "A special supplemental group that applies to
+ all containers in a pod. Some volume types allow the Kubelet
+ to change the ownership of that volume to be owned by the
+ pod: \n 1. The owning GID will be the FSGroup 2. The setgid
+ bit is set (new files created in the volume will be owned
+ by FSGroup) 3. The permission bits are OR'd with rw-rw----
+ \n If unset, the Kubelet will not modify the ownership and
+ permissions of any volume. Note that this field cannot be
+ set when spec.os.name is windows."
+ format: int64
+ type: integer
+ fsGroupChangePolicy:
+ description: 'fsGroupChangePolicy defines behavior of changing
+ ownership and permission of the volume before being exposed
+ inside Pod. This field will only apply to volume types which
+ support fsGroup based ownership(and permissions). It will
+ have no effect on ephemeral volume types such as: secret,
+ configmaps and emptydir. Valid values are "OnRootMismatch"
+ and "Always". If not specified, "Always" is used. Note that
+ this field cannot be set when spec.os.name is windows.'
+ type: string
+ runAsGroup:
+ description: The GID to run the entrypoint of the container
+ process. Uses runtime default if unset. May also be set
+ in SecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence for that container. Note that this field
+ cannot be set when spec.os.name is windows.
+ format: int64
+ type: integer
+ runAsNonRoot:
+ description: Indicates that the container must run as a non-root
+ user. If true, the Kubelet will validate the image at runtime
+ to ensure that it does not run as UID 0 (root) and fail
+ to start the container if it does. If unset or false, no
+ such validation will be performed. May also be set in SecurityContext. If
+ set in both SecurityContext and PodSecurityContext, the
+ value specified in SecurityContext takes precedence.
+ type: boolean
+ runAsUser:
+ description: The UID to run the entrypoint of the container
+ process. Defaults to user specified in image metadata if
+ unspecified. May also be set in SecurityContext. If set
+ in both SecurityContext and PodSecurityContext, the value
+ specified in SecurityContext takes precedence for that container.
+ Note that this field cannot be set when spec.os.name is
+ windows.
+ format: int64
+ type: integer
+ seLinuxOptions:
+ description: The SELinux context to be applied to all containers.
+ If unspecified, the container runtime will allocate a random
+ SELinux context for each container. May also be set in
+ SecurityContext. If set in both SecurityContext and PodSecurityContext,
+ the value specified in SecurityContext takes precedence
+ for that container. Note that this field cannot be set when
+ spec.os.name is windows.
+ properties:
+ level:
+ description: Level is SELinux level label that applies
+ to the container.
+ type: string
+ role:
+ description: Role is a SELinux role label that applies
+ to the container.
+ type: string
+ type:
+ description: Type is a SELinux type label that applies
+ to the container.
+ type: string
+ user:
+ description: User is a SELinux user label that applies
+ to the container.
+ type: string
+ type: object
+ seccompProfile:
+ description: The seccomp options to use by the containers
+ in this pod. Note that this field cannot be set when spec.os.name
+ is windows.
+ properties:
+ localhostProfile:
+ description: localhostProfile indicates a profile defined
+ in a file on the node should be used. The profile must
+ be preconfigured on the node to work. Must be a descending
+ path, relative to the kubelet's configured seccomp profile
+ location. Must only be set if type is "Localhost".
+ type: string
+ type:
+ description: "type indicates which kind of seccomp profile
+ will be applied. Valid options are: \n Localhost - a
+ profile defined in a file on the node should be used.
+ RuntimeDefault - the container runtime default profile
+ should be used. Unconfined - no profile should be applied."
+ type: string
+ required:
+ - type
+ type: object
+ supplementalGroups:
+ description: A list of groups applied to the first process
+ run in each container, in addition to the container's primary
+ GID, the fsGroup (if specified), and group memberships defined
+ in the container image for the uid of the container process.
+ If unspecified, no additional groups are added to any container.
+ Note that group memberships defined in the container image
+ for the uid of the container process are still effective,
+ even if they are not included in this list. Note that this
+ field cannot be set when spec.os.name is windows.
+ items:
+ format: int64
+ type: integer
+ type: array
+ sysctls:
+ description: Sysctls hold a list of namespaced sysctls used
+ for the pod. Pods with unsupported sysctls (by the container
+ runtime) might fail to launch. Note that this field cannot
+ be set when spec.os.name is windows.
+ items:
+ description: Sysctl defines a kernel parameter to be set
+ properties:
+ name:
+ description: Name of a property to set
+ type: string
+ value:
+ description: Value of a property to set
+ type: string
+ required:
+ - name
+ - value
+ type: object
+ type: array
+ windowsOptions:
+ description: The Windows specific settings applied to all
+ containers. If unspecified, the options within a container's
+ SecurityContext will be used. If set in both SecurityContext
+ and PodSecurityContext, the value specified in SecurityContext
+ takes precedence. Note that this field cannot be set when
+ spec.os.name is linux.
+ properties:
+ gmsaCredentialSpec:
+ description: GMSACredentialSpec is where the GMSA admission
+ webhook (https://github.com/kubernetes-sigs/windows-gmsa)
+ inlines the contents of the GMSA credential spec named
+ by the GMSACredentialSpecName field.
+ type: string
+ gmsaCredentialSpecName:
+ description: GMSACredentialSpecName is the name of the
+ GMSA credential spec to use.
+ type: string
+ hostProcess:
+ description: HostProcess determines if a container should
+ be run as a 'Host Process' container. This field is
+ alpha-level and will only be honored by components that
+ enable the WindowsHostProcessContainers feature flag.
+ Setting this field without the feature flag will result
+ in errors when validating the Pod. All of a Pod's containers
+ must have the same effective HostProcess value (it is
+ not allowed to have a mix of HostProcess containers
+ and non-HostProcess containers). In addition, if HostProcess
+ is true then HostNetwork must also be set to true.
+ type: boolean
+ runAsUserName:
+ description: The UserName in Windows to run the entrypoint
+ of the container process. Defaults to the user specified
+ in image metadata if unspecified. May also be set in
+ PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence.
+ type: string
+ type: object
+ type: object
+ service:
+ description: 'expose doris components for accessing. example:
+ if you want to use `stream load` to load data into doris out
+ k8s, you can use be service and config different service type
+ for loading data.'
+ properties:
+ annotations:
+ additionalProperties:
+ type: string
+ description: Annotations for using function on different cloud
+ platform.
+ type: object
+ loadBalancerIP:
+ description: 'Only applies to Service Type: LoadBalancer.
+ This feature depends on whether the underlying cloud-provider
+ supports specifying the loadBalancerIP when a load balancer
+ is created. This field will be ignored if the cloud-provider
+ does not support the feature. This field was under-specified
+ and its meaning varies across implementations, and it cannot
+ support dual-stack. As of Kubernetes v1.24, users are encouraged
+ to use implementation-specific annotations when available.
+ This field may be removed in a future API version.'
+ type: string
+ servicePorts:
+ description: ServicePort config service for NodePort access
+ mode.
+ items:
+ description: DorisServicePort for ServiceType=NodePort situation.
+ properties:
+ nodePort:
+ description: 'The port on each node on which this service
+ is exposed when type is NodePort or LoadBalancer. Usually
+ assigned by the system. If a value is specified, in-range,
+ and not in use it will be used, otherwise the operation
+ will fail. If not specified, a port will be allocated
+ if this Service requires one. If this field is specified
+ when creating a Service which does not need it, creation
+ will fail. This field will be wiped when updating
+ a Service to no longer need it (e.g. changing type
+ from NodePort to ClusterIP). More info: https://kubernetes.io/docs/concepts/services-networking/service/#type-nodeport
+ need in 30000-32767'
+ format: int32
+ type: integer
+ targetPort:
+ description: 'Number or name of the port to access on
+ the pods targeted by the service. Number must be in
+ the range 1 to 65535. Name must be an IANA_SVC_NAME.
+ If this is a string, it will be looked up as a named
+ port in the target Pod''s container ports. If this
+ is not specified, the value of the ''port'' field
+ is used (an identity map). This field is ignored for
+ services with clusterIP=None, and should be omitted
+ or set equal to the ''port'' field. More info: https://kubernetes.io/docs/concepts/services-networking/service/#defining-a-service'
+ format: int32
+ type: integer
+ type: object
+ type: array
+ type:
+ description: 'type of service,the possible value for the service
+ type are : ClusterIP, NodePort, LoadBalancer,ExternalName.
+ More info: https://kubernetes.io/docs/concepts/services-networking/service/#publishing-services-service-types'
+ type: string
+ type: object
+ serviceAccount:
+ description: serviceAccount for cn access cloud service.
+ type: string
+ systemInitialization:
+ description: SystemInitialization for fe, be and cn setting system
+ parameters.
+ properties:
+ args:
+ description: Arguments to the entrypoint.
+ items:
+ type: string
+ type: array
+ command:
+ description: Entrypoint array. Not executed within a shell.
+ items:
+ type: string
+ type: array
+ initImage:
+ description: Image for doris initialization, default is selectdb/alpine:latest.
+ type: string
+ type: object
+ tolerations:
+ description: (Optional) Tolerations for scheduling pods onto some
+ dedicated nodes
+ items:
+ description: The pod this Toleration is attached to tolerates
+ any taint that matches the triple using
+ the matching operator .
+ properties:
+ effect:
+ description: Effect indicates the taint effect to match.
+ Empty means match all taint effects. When specified, allowed
+ values are NoSchedule, PreferNoSchedule and NoExecute.
+ type: string
+ key:
+ description: Key is the taint key that the toleration applies
+ to. Empty means match all taint keys. If the key is empty,
+ operator must be Exists; this combination means to match
+ all values and all keys.
+ type: string
+ operator:
+ description: Operator represents a key's relationship to
+ the value. Valid operators are Exists and Equal. Defaults
+ to Equal. Exists is equivalent to wildcard for value,
+ so that a pod can tolerate all taints of a particular
+ category.
+ type: string
+ tolerationSeconds:
+ description: TolerationSeconds represents the period of
+ time the toleration (which must be of effect NoExecute,
+ otherwise this field is ignored) tolerates the taint.
+ By default, it is not set, which means tolerate the taint
+ forever (do not evict). Zero and negative values will
+ be treated as 0 (evict immediately) by the system.
+ format: int64
+ type: integer
+ value:
+ description: Value is the taint value the toleration matches
+ to. If the operator is Exists, the value should be empty,
+ otherwise just a regular string.
+ type: string
+ type: object
+ type: array
+ required:
+ - image
+ type: object
+ cnSpec:
+ description: defines the cn cluster state that will be created by
+ operator.
+ properties:
+ affinity:
+ description: If specified, the pod's scheduling constraints.
+ properties:
+ nodeAffinity:
+ description: Describes node affinity scheduling rules for
+ the pod.
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ items:
+ description: An empty preferred scheduling term matches
+ all objects with implicit weight 0 (i.e. it's a no-op).
+ A null preferred scheduling term matches no objects
+ (i.e. is also a no-op).
+ properties:
+ preference:
+ description: A node selector term, associated with
+ the corresponding weight.
+ properties:
+ matchExpressions:
+ description: A list of node selector requirements
+ by node's labels.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchFields:
+ description: A list of node selector requirements
+ by node's fields.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ type: object
+ x-kubernetes-map-type: atomic
+ weight:
+ description: Weight associated with matching the
+ corresponding nodeSelectorTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - preference
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ description: If the affinity requirements specified by
+ this field are not met at scheduling time, the pod will
+ not be scheduled onto the node. If the affinity requirements
+ specified by this field cease to be met at some point
+ during pod execution (e.g. due to an update), the system
+ may or may not try to eventually evict the pod from
+ its node.
+ properties:
+ nodeSelectorTerms:
+ description: Required. A list of node selector terms.
+ The terms are ORed.
+ items:
+ description: A null or empty node selector term
+ matches no objects. The requirements of them are
+ ANDed. The TopologySelectorTerm type implements
+ a subset of the NodeSelectorTerm.
+ properties:
+ matchExpressions:
+ description: A list of node selector requirements
+ by node's labels.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchFields:
+ description: A list of node selector requirements
+ by node's fields.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ description: An array of string values.
+ If the operator is In or NotIn, the
+ values array must be non-empty. If the
+ operator is Exists or DoesNotExist,
+ the values array must be empty. If the
+ operator is Gt or Lt, the values array
+ must have a single element, which will
+ be interpreted as an integer. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ type: object
+ x-kubernetes-map-type: atomic
+ type: array
+ required:
+ - nodeSelectorTerms
+ type: object
+ x-kubernetes-map-type: atomic
+ type: object
+ podAffinity:
+ description: Describes pod affinity scheduling rules (e.g.
+ co-locate this pod in the same node, zone, etc. as some
+ other pod(s)).
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ description: The scheduler will prefer to schedule pods
+ to nodes that satisfy the affinity expressions specified
+ by this field, but it may choose a node that violates
+ one or more of the expressions. The node that is most
+ preferred is the one with the greatest sum of weights,
+ i.e. for each node that meets all of the scheduling
+ requirements (resource request, requiredDuringScheduling
+ affinity expressions, etc.), compute a sum by iterating
+ through the elements of this field and adding "weight"
+ to the sum if the node has pods which matches the corresponding
+ podAffinityTerm; the node(s) with the highest sum are
+ the most preferred.
+ items:
+ description: The weights of all of the matched WeightedPodAffinityTerm
+ fields are added per-node to find the most preferred
+ node(s)
+ properties:
+ podAffinityTerm:
+ description: Required. A pod affinity term, associated
+ with the corresponding weight.
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by
+ this field and the ones listed in the namespaces
+ field. null selector and null or empty namespaces
+ list means "this pod's namespace". An empty
+ selector ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to.
+ The term is applied to the union of the namespaces
+ listed in this field and the ones selected
+ by namespaceSelector. null or empty namespaces
+ list and null namespaceSelector means "this
+ pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the
+ pods matching the labelSelector in the specified
+ namespaces, where co-located is defined as
+ running on a node whose value of the label
+ with key topologyKey matches that of any node
+ on which any of the selected pods is running.
+ Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ weight:
+ description: weight associated with matching the
+ corresponding podAffinityTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - podAffinityTerm
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ description: If the affinity requirements specified by
+ this field are not met at scheduling time, the pod will
+ not be scheduled onto the node. If the affinity requirements
+ specified by this field cease to be met at some point
+ during pod execution (e.g. due to a pod label update),
+ the system may or may not try to eventually evict the
+ pod from its node. When there are multiple elements,
+ the lists of nodes corresponding to each podAffinityTerm
+ are intersected, i.e. all terms must be satisfied.
+ items:
+ description: Defines a set of pods (namely those matching
+ the labelSelector relative to the given namespace(s))
+ that this pod should be co-located (affinity) or not
+ co-located (anti-affinity) with, where co-located
+ is defined as running on a node whose value of the
+ label with key matches that of any node
+ on which a pod of the set of pods is running
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by this
+ field and the ones listed in the namespaces field.
+ null selector and null or empty namespaces list
+ means "this pod's namespace". An empty selector
+ ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to. The
+ term is applied to the union of the namespaces
+ listed in this field and the ones selected by
+ namespaceSelector. null or empty namespaces list
+ and null namespaceSelector means "this pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the pods
+ matching the labelSelector in the specified namespaces,
+ where co-located is defined as running on a node
+ whose value of the label with key topologyKey
+ matches that of any node on which any of the selected
+ pods is running. Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ type: array
+ type: object
+ podAntiAffinity:
+ description: Describes pod anti-affinity scheduling rules
+ (e.g. avoid putting this pod in the same node, zone, etc.
+ as some other pod(s)).
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ description: The scheduler will prefer to schedule pods
+ to nodes that satisfy the anti-affinity expressions
+ specified by this field, but it may choose a node that
+ violates one or more of the expressions. The node that
+ is most preferred is the one with the greatest sum of
+ weights, i.e. for each node that meets all of the scheduling
+ requirements (resource request, requiredDuringScheduling
+ anti-affinity expressions, etc.), compute a sum by iterating
+ through the elements of this field and adding "weight"
+ to the sum if the node has pods which matches the corresponding
+ podAffinityTerm; the node(s) with the highest sum are
+ the most preferred.
+ items:
+ description: The weights of all of the matched WeightedPodAffinityTerm
+ fields are added per-node to find the most preferred
+ node(s)
+ properties:
+ podAffinityTerm:
+ description: Required. A pod affinity term, associated
+ with the corresponding weight.
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by
+ this field and the ones listed in the namespaces
+ field. null selector and null or empty namespaces
+ list means "this pod's namespace". An empty
+ selector ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ description: values is an array of
+ string values. If the operator is
+ In or NotIn, the values array must
+ be non-empty. If the operator is
+ Exists or DoesNotExist, the values
+ array must be empty. This array
+ is replaced during a strategic merge
+ patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to.
+ The term is applied to the union of the namespaces
+ listed in this field and the ones selected
+ by namespaceSelector. null or empty namespaces
+ list and null namespaceSelector means "this
+ pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the
+ pods matching the labelSelector in the specified
+ namespaces, where co-located is defined as
+ running on a node whose value of the label
+ with key topologyKey matches that of any node
+ on which any of the selected pods is running.
+ Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ weight:
+ description: weight associated with matching the
+ corresponding podAffinityTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - podAffinityTerm
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ items:
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ description: A label query over the set of namespaces
+ that the term applies to. The term is applied
+ to the union of the namespaces selected by this
+ field and the ones listed in the namespaces field.
+ null selector and null or empty namespaces list
+ means "this pod's namespace". An empty selector
+ ({}) matches all namespaces.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of {key,value}
+ pairs. A single {key,value} in the matchLabels
+ map is equivalent to an element of matchExpressions,
+ whose key field is "key", the operator is
+ "In", and the values array contains only "value".
+ The requirements are ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ description: namespaces specifies a static list
+ of namespace names that the term applies to. The
+ term is applied to the union of the namespaces
+ listed in this field and the ones selected by
+ namespaceSelector. null or empty namespaces list
+ and null namespaceSelector means "this pod's namespace".
+ items:
+ type: string
+ type: array
+ topologyKey:
+ description: This pod should be co-located (affinity)
+ or not co-located (anti-affinity) with the pods
+ matching the labelSelector in the specified namespaces,
+ where co-located is defined as running on a node
+ whose value of the label with key topologyKey
+ matches that of any node on which any of the selected
+ pods is running. Empty topologyKey is not allowed.
+ type: string
+ required:
+ - topologyKey
+ type: object
+ type: array
+ type: object
+ type: object
+ annotations:
+ additionalProperties:
+ type: string
+ description: annotation for fe pods. user can config monitor annotation
+ for collect to monitor system.
+ type: object
+ autoScalingPolicy:
+ description: AutoScalingPolicy auto scaling strategy
+ properties:
+ hpaPolicy:
+ description: the policy of cn autoscale. operator use autoscaling
+ v2.
+ properties:
+ behavior:
+ description: HorizontalPodAutoscalerBehavior configures
+ the scaling behavior of the target. the struct copy
+ from k8s.io/api/autoscaling/v2beta2/types.go. the redundancy
+ code will hide the restriction about HorizontalPodAutoscaler
+ version and kubernetes releases matching issue. the
+ properties:
+ scaleDown:
+ description: scaleDown is scaling policy for scaling
+ Down. If not set, the default value is to allow
+ to scale down to minReplicas pods, with a 300 second
+ stabilization window (i.e., the highest recommendation
+ for the last 300sec is used).
+ properties:
+ policies:
+ description: policies is a list of potential scaling
+ polices which can be used during scaling. At
+ least one policy must be specified, otherwise
+ the HPAScalingRules will be discarded as invalid
+ items:
+ description: HPAScalingPolicy is a single policy
+ which must hold true for a specified past
+ interval.
+ properties:
+ periodSeconds:
+ description: PeriodSeconds specifies the
+ window of time for which the policy should
+ hold true. PeriodSeconds must be greater
+ than zero and less than or equal to 1800
+ (30 min).
+ format: int32
+ type: integer
+ type:
+ description: Type is used to specify the
+ scaling policy.
+ type: string
+ value:
+ description: Value contains the amount of
+ change which is permitted by the policy.
+ It must be greater than zero
+ format: int32
+ type: integer
+ required:
+ - periodSeconds
+ - type
+ - value
+ type: object
+ type: array
+ selectPolicy:
+ description: selectPolicy is used to specify which
+ policy should be used. If not set, the default
+ value MaxPolicySelect is used.
+ type: string
+ stabilizationWindowSeconds:
+ description: 'StabilizationWindowSeconds is the
+ number of seconds for which past recommendations
+ should be considered while scaling up or scaling
+ down. StabilizationWindowSeconds must be greater
+ than or equal to zero and less than or equal
+ to 3600 (one hour). If not set, use the default
+ values: - For scale up: 0 (i.e. no stabilization
+ is done). - For scale down: 300 (i.e. the stabilization
+ window is 300 seconds long).'
+ format: int32
+ type: integer
+ type: object
+ scaleUp:
+ description: 'scaleUp is scaling policy for scaling
+ Up. If not set, the default value is the higher
+ of: * increase no more than 4 pods per 60 seconds
+ * double the number of pods per 60 seconds No stabilization
+ is used.'
+ properties:
+ policies:
+ description: policies is a list of potential scaling
+ polices which can be used during scaling. At
+ least one policy must be specified, otherwise
+ the HPAScalingRules will be discarded as invalid
+ items:
+ description: HPAScalingPolicy is a single policy
+ which must hold true for a specified past
+ interval.
+ properties:
+ periodSeconds:
+ description: PeriodSeconds specifies the
+ window of time for which the policy should
+ hold true. PeriodSeconds must be greater
+ than zero and less than or equal to 1800
+ (30 min).
+ format: int32
+ type: integer
+ type:
+ description: Type is used to specify the
+ scaling policy.
+ type: string
+ value:
+ description: Value contains the amount of
+ change which is permitted by the policy.
+ It must be greater than zero
+ format: int32
+ type: integer
+ required:
+ - periodSeconds
+ - type
+ - value
+ type: object
+ type: array
+ selectPolicy:
+ description: selectPolicy is used to specify which
+ policy should be used. If not set, the default
+ value MaxPolicySelect is used.
+ type: string
+ stabilizationWindowSeconds:
+ description: 'StabilizationWindowSeconds is the
+ number of seconds for which past recommendations
+ should be considered while scaling up or scaling
+ down. StabilizationWindowSeconds must be greater
+ than or equal to zero and less than or equal
+ to 3600 (one hour). If not set, use the default
+ values: - For scale up: 0 (i.e. no stabilization
+ is done). - For scale down: 300 (i.e. the stabilization
+ window is 300 seconds long).'
+ format: int32
+ type: integer
+ type: object
+ type: object
+ metrics:
+ items:
+ description: MetricSpec specifies how to scale based
+ on a single metric (only `type` and one other matching
+ field should be set at once).
+ properties:
+ containerResource:
+ properties:
+ container:
+ description: container is the name of the container
+ in the pods of the scaling target
+ type: string
+ name:
+ description: name is the name of the resource
+ in question.
+ type: string
+ target:
+ description: target specifies the target value
+ for the given metric
+ properties:
+ averageUtilization:
+ description: averageUtilization is the target
+ value of the average of the resource metric
+ across all relevant pods, represented
+ as a percentage of the requested value
+ of the resource for the pods. Currently
+ only valid for Resource metric source
+ type
+ format: int32
+ type: integer
+ averageValue:
+ anyOf:
+ - type: integer
+ - type: string
+ description: averageValue is the target
+ value of the average of the metric across
+ all relevant pods (as a quantity)
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ type:
+ description: type represents whether the
+ metric type is Utilization, Value, or
+ AverageValue
+ type: string
+ value:
+ anyOf:
+ - type: integer
+ - type: string
+ description: value is the target value of
+ the metric (as a quantity).
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ required:
+ - type
+ type: object
+ required:
+ - container
+ - name
+ - target
+ type: object
+ external:
+ description: external refers to a global metric
+ that is not associated with any Kubernetes object.
+ It allows autoscaling based on information coming
+ from components running outside of cluster (for
+ example length of queue in cloud messaging service,
+ or QPS from loadbalancer running outside of cluster).
+ properties:
+ metric:
+ description: metric identifies the target metric
+ by name and selector
+ properties:
+ name:
+ description: name is the name of the given
+ metric
+ type: string
+ selector:
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The
+ requirements are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label
+ key that the selector applies
+ to.
+ type: string
+ operator:
+ description: operator represents
+ a key's relationship to a set
+ of values. Valid operators are
+ In, NotIn, Exists and DoesNotExist.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of
+ {key,value} pairs. A single {key,value}
+ in the matchLabels map is equivalent
+ to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are
+ ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ required:
+ - name
+ type: object
+ target:
+ description: target specifies the target value
+ for the given metric
+ properties:
+ averageUtilization:
+ description: averageUtilization is the target
+ value of the average of the resource metric
+ across all relevant pods, represented
+ as a percentage of the requested value
+ of the resource for the pods. Currently
+ only valid for Resource metric source
+ type
+ format: int32
+ type: integer
+ averageValue:
+ anyOf:
+ - type: integer
+ - type: string
+ description: averageValue is the target
+ value of the average of the metric across
+ all relevant pods (as a quantity)
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ type:
+ description: type represents whether the
+ metric type is Utilization, Value, or
+ AverageValue
+ type: string
+ value:
+ anyOf:
+ - type: integer
+ - type: string
+ description: value is the target value of
+ the metric (as a quantity).
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ required:
+ - type
+ type: object
+ required:
+ - metric
+ - target
+ type: object
+ object:
+ description: object refers to a metric describing
+ a single kubernetes object (for example, hits-per-second
+ on an Ingress object).
+ properties:
+ describedObject:
+ description: CrossVersionObjectReference contains
+ enough information to let you identify the
+ referred resource.
+ properties:
+ apiVersion:
+ description: API version of the referent
+ type: string
+ kind:
+ description: 'Kind of the referent; More
+ info: https://git.k8s.io/community/contributors/devel/sig-architecture/api-conventions.md#types-kinds"'
+ type: string
+ name:
+ description: 'Name of the referent; More
+ info: http://kubernetes.io/docs/user-guide/identifiers#names'
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ metric:
+ description: metric identifies the target metric
+ by name and selector
+ properties:
+ name:
+ description: name is the name of the given
+ metric
+ type: string
+ selector:
+ description: selector is the string-encoded
+ form of a standard kubernetes label selector
+ for the given metric When set, it is passed
+ as an additional parameter to the metrics
+ server for more specific metrics scoping.
+ When unset, just the metricName will be
+ used to gather metrics.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The
+ requirements are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label
+ key that the selector applies
+ to.
+ type: string
+ operator:
+ description: operator represents
+ a key's relationship to a set
+ of values. Valid operators are
+ In, NotIn, Exists and DoesNotExist.
+ type: string
+ values:
+ description: values is an array
+ of string values. If the operator
+ is In or NotIn, the values array
+ must be non-empty. If the operator
+ is Exists or DoesNotExist, the
+ values array must be empty.
+ This array is replaced during
+ a strategic merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of
+ {key,value} pairs. A single {key,value}
+ in the matchLabels map is equivalent
+ to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are
+ ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ required:
+ - name
+ type: object
+ target:
+ description: target specifies the target value
+ for the given metric
+ properties:
+ averageUtilization:
+ description: averageUtilization is the target
+ value of the average of the resource metric
+ across all relevant pods, represented
+ as a percentage of the requested value
+ of the resource for the pods. Currently
+ only valid for Resource metric source
+ type
+ format: int32
+ type: integer
+ averageValue:
+ anyOf:
+ - type: integer
+ - type: string
+ description: averageValue is the target
+ value of the average of the metric across
+ all relevant pods (as a quantity)
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ type:
+ description: type represents whether the
+ metric type is Utilization, Value, or
+ AverageValue
+ type: string
+ value:
+ anyOf:
+ - type: integer
+ - type: string
+ description: value is the target value of
+ the metric (as a quantity).
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ required:
+ - type
+ type: object
+ required:
+ - describedObject
+ - metric
+ - target
+ type: object
+ pods:
+ description: pods refers to a metric describing
+ each pod in the current scale target (for example,
+ transactions-processed-per-second). The values
+ will be averaged together before being compared
+ to the target value.
+ properties:
+ metric:
+ description: metric identifies the target metric
+ by name and selector
+ properties:
+ name:
+ description: name is the name of the given
+ metric
+ type: string
+ selector:
+ description: selector is the string-encoded
+ form of a standard kubernetes label selector
+ for the given metric When set, it is passed
+ as an additional parameter to the metrics
+ server for more specific metrics scoping.
+ When unset, just the metricName will be
+ used to gather metrics.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The
+ requirements are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label
+ key that the selector applies
+ to.
+ type: string
+ operator:
+ description: operator represents
+ a key's relationship to a set
+ of values. Valid operators are
+ In, NotIn, Exists and DoesNotExist.
+ type: string
+ values:
+ description: values is an array
+ of string values. If the operator
+ is In or NotIn, the values array
+ must be non-empty. If the operator
+ is Exists or DoesNotExist, the
+ values array must be empty.
+ This array is replaced during
+ a strategic merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ description: matchLabels is a map of
+ {key,value} pairs. A single {key,value}
+ in the matchLabels map is equivalent
+ to an element of matchExpressions,
+ whose key field is "key", the operator
+ is "In", and the values array contains
+ only "value". The requirements are
+ ANDed.
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ required:
+ - name
+ type: object
+ target:
+ description: target specifies the target value
+ for the given metric
+ properties:
+ averageUtilization:
+ description: averageUtilization is the target
+ value of the average of the resource metric
+ across all relevant pods, represented
+ as a percentage of the requested value
+ of the resource for the pods. Currently
+ only valid for Resource metric source
+ type
+ format: int32
+ type: integer
+ averageValue:
+ anyOf:
+ - type: integer
+ - type: string
+ description: averageValue is the target
+ value of the average of the metric across
+ all relevant pods (as a quantity)
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ type:
+ description: type represents whether the
+ metric type is Utilization, Value, or
+ AverageValue
+ type: string
+ value:
+ anyOf:
+ - type: integer
+ - type: string
+ description: value is the target value of
+ the metric (as a quantity).
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ required:
+ - type
+ type: object
+ required:
+ - metric
+ - target
+ type: object
+ resource:
+ description: resource refers to a resource metric
+ (such as those specified in requests and limits)
+ known to Kubernetes describing each pod in the
+ current scale target (e.g. CPU or memory). Such
+ metrics are built in to Kubernetes, and have special
+ scaling options on top of those available to normal
+ per-pod metrics using the "pods" source.
+ properties:
+ name:
+ description: name is the name of the resource
+ in question.
+ type: string
+ target:
+ description: target specifies the target value
+ for the given metric
+ properties:
+ averageUtilization:
+ description: averageUtilization is the target
+ value of the average of the resource metric
+ across all relevant pods, represented
+ as a percentage of the requested value
+ of the resource for the pods. Currently
+ only valid for Resource metric source
+ type
+ format: int32
+ type: integer
+ averageValue:
+ anyOf:
+ - type: integer
+ - type: string
+ description: averageValue is the target
+ value of the average of the metric across
+ all relevant pods (as a quantity)
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ type:
+ description: type represents whether the
+ metric type is Utilization, Value, or
+ AverageValue
+ type: string
+ value:
+ anyOf:
+ - type: integer
+ - type: string
+ description: value is the target value of
+ the metric (as a quantity).
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ required:
+ - type
+ type: object
+ required:
+ - name
+ - target
+ type: object
+ type:
+ description: 'type is the type of metric source. It
+ should be one of "ContainerResource", "External",
+ "Object", "Pods" or "Resource", each mapping to
+ a matching field in the object. Note: "ContainerResource"
+ type is available on when the feature-gate HPAContainerMetrics
+ is enabled'
+ type: string
+ required:
+ - type
+ type: object
+ type: array
+ type: object
+ maxReplicas:
+ description: the max numbers of target.
+ format: int32
+ type: integer
+ minReplicas:
+ description: the min numbers of target.
+ format: int32
+ type: integer
+ version:
+ default: v2
+ description: version represents the autoscaler version for
+ cn service. only support v1,,v2
+ type: string
+ type: object
+ claims:
+ description: "Claims lists the names of resources, defined in
+ spec.resourceClaims, that are used by this container. \n This
+ is an alpha field and requires enabling the DynamicResourceAllocation
+ feature gate. \n This field is immutable."
+ items:
+ description: ResourceClaim references one entry in PodSpec.ResourceClaims.
+ properties:
+ name:
+ description: Name must match the name of one entry in pod.spec.resourceClaims
+ of the Pod where this field is used. It makes that resource
+ available inside a container.
+ type: string
+ required:
+ - name
+ type: object
+ type: array
+ x-kubernetes-list-map-keys:
+ - name
+ x-kubernetes-list-type: map
+ configMapInfo:
+ description: the reference for cn configMap.
+ properties:
+ configMapName:
+ description: ConfigMapName mapped the configuration files
+ in the doris 'conf/' directory. such as 'fe.conf', 'be.conf'.
+ If HDFS access is involved, there may also be 'core-site.xml'
+ and other files. doris-operator mounts these configuration
+ files in the '/etc/doris' directory by default. links them
+ to the 'conf/' directory of the doris component through
+ soft links.
+ type: string
+ configMaps:
+ description: ConfigMaps can mount multiple configmaps to the
+ specified path. The mounting path of configmap cannot be
+ repeated.
+ items:
+ properties:
+ configMapName:
+ description: name of configmap that needs to mount.
+ type: string
+ mountPath:
+ description: Current ConfigMap Mount Path. If MountConfigMapInfo
+ belongs to the same ConfigMapInfo, their MountPath
+ cannot be repeated.
+ type: string
+ type: object
+ type: array
+ resolveKey:
+ description: 'Deprecated: This configuration has been abandoned
+ and will be cleared in version 1.7.0. It is currently forced
+ to be ''fe.conf'', ''be.conf'', ''apache_hdfs_broker.conf''
+ It is no longer effective. the configuration content will
+ not take effect.'
+ type: string
+ type: object
+ containerSecurityContext:
+ description: Security context for all containers running in the
+ pod (unless they override it).
+ properties:
+ allowPrivilegeEscalation:
+ description: 'AllowPrivilegeEscalation controls whether a
+ process can gain more privileges than its parent process.
+ This bool directly controls if the no_new_privs flag will
+ be set on the container process. AllowPrivilegeEscalation
+ is true always when the container is: 1) run as Privileged
+ 2) has CAP_SYS_ADMIN Note that this field cannot be set
+ when spec.os.name is windows.'
+ type: boolean
+ capabilities:
+ description: The capabilities to add/drop when running containers.
+ Defaults to the default set of capabilities granted by the
+ container runtime. Note that this field cannot be set when
+ spec.os.name is windows.
+ properties:
+ add:
+ description: Added capabilities
+ items:
+ description: Capability represent POSIX capabilities
+ type
+ type: string
+ type: array
+ drop:
+ description: Removed capabilities
+ items:
+ description: Capability represent POSIX capabilities
+ type
+ type: string
+ type: array
+ type: object
+ privileged:
+ description: Run container in privileged mode. Processes in
+ privileged containers are essentially equivalent to root
+ on the host. Defaults to false. Note that this field cannot
+ be set when spec.os.name is windows.
+ type: boolean
+ procMount:
+ description: procMount denotes the type of proc mount to use
+ for the containers. The default is DefaultProcMount which
+ uses the container runtime defaults for readonly paths and
+ masked paths. This requires the ProcMountType feature flag
+ to be enabled. Note that this field cannot be set when spec.os.name
+ is windows.
+ type: string
+ readOnlyRootFilesystem:
+ description: Whether this container has a read-only root filesystem.
+ Default is false. Note that this field cannot be set when
+ spec.os.name is windows.
+ type: boolean
+ runAsGroup:
+ description: The GID to run the entrypoint of the container
+ process. Uses runtime default if unset. May also be set
+ in PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence. Note that this field cannot be set when
+ spec.os.name is windows.
+ format: int64
+ type: integer
+ runAsNonRoot:
+ type: boolean
+ runAsUser:
+ format: int64
+ type: integer
+ seLinuxOptions:
+ properties:
+ level:
+ description: Level is SELinux level label that applies
+ to the container.
+ type: string
+ role:
+ description: Role is a SELinux role label that applies
+ to the container.
+ type: string
+ type:
+ description: Type is a SELinux type label that applies
+ to the container.
+ type: string
+ user:
+ description: User is a SELinux user label that applies
+ to the container.
+ type: string
+ type: object
+ seccompProfile:
+ description: The seccomp options to use by this container.
+ If seccomp options are provided at both the pod & container
+ level, the container options override the pod options. Note
+ that this field cannot be set when spec.os.name is windows.
+ properties:
+ localhostProfile:
+ description: localhostProfile indicates a profile defined
+ in a file on the node should be used. The profile must
+ be preconfigured on the node to work. Must be a descending
+ path, relative to the kubelet's configured seccomp profile
+ location. Must only be set if type is "Localhost".
+ type: string
+ type:
+ description: "type indicates which kind of seccomp profile
+ will be applied. Valid options are: \n Localhost - a
+ profile defined in a file on the node should be used.
+ RuntimeDefault - the container runtime default profile
+ should be used. Unconfined - no profile should be applied."
+ type: string
+ required:
+ - type
+ type: object
+ windowsOptions:
+ description: The Windows specific settings applied to all
+ containers. If unspecified, the options from the PodSecurityContext
+ will be used. If set in both SecurityContext and PodSecurityContext,
+ the value specified in SecurityContext takes precedence.
+ Note that this field cannot be set when spec.os.name is
+ linux.
+ properties:
+ gmsaCredentialSpec:
+ description: GMSACredentialSpec is where the GMSA admission
+ webhook (https://github.com/kubernetes-sigs/windows-gmsa)
+ inlines the contents of the GMSA credential spec named
+ by the GMSACredentialSpecName field.
+ type: string
+ gmsaCredentialSpecName:
+ description: GMSACredentialSpecName is the name of the
+ GMSA credential spec to use.
+ type: string
+ hostProcess:
+ type: boolean
+ runAsUserName:
+ description: The UserName in Windows to run the entrypoint
+ of the container process. Defaults to the user specified
+ in image metadata if unspecified. May also be set in
+ PodSecurityContext. If set in both SecurityContext and
+ PodSecurityContext, the value specified in SecurityContext
+ takes precedence.
+ type: string
+ type: object
+ type: object
+ envVars:
+ description: cnEnvVars is a slice of environment variables that
+ are added to the pods, the default is empty.
+ items:
+ description: EnvVar represents an environment variable present
+ in a Container.
+ properties:
+ name:
+ description: Name of the environment variable. Must be a
+ C_IDENTIFIER.
+ type: string
+ value:
+ type: string
+ valueFrom:
+ description: Source for the environment variable's value.
+ Cannot be used if value is not empty.
+ properties:
+ configMapKeyRef:
+ description: Selects a key of a ConfigMap.
+ properties:
+ key:
+ description: The key to select.
+ type: string
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind,
+ uid?'
+ type: string
+ optional:
+ description: Specify whether the ConfigMap or its
+ key must be defined
+ type: boolean
+ required:
+ - key
+ type: object
+ x-kubernetes-map-type: atomic
+ fieldRef:
+ description: 'Selects a field of the pod: supports metadata.name,
+ metadata.namespace, `metadata.labels['''']`,
+ `metadata.annotations['''']`, spec.nodeName,
+ spec.serviceAccountName, status.hostIP, status.podIP,
+ status.podIPs.'
+ properties:
+ apiVersion:
+ description: Version of the schema the FieldPath
+ is written in terms of, defaults to "v1".
+ type: string
+ fieldPath:
+ description: Path of the field to select in the
+ specified API version.
+ type: string
+ required:
+ - fieldPath
+ type: object
+ x-kubernetes-map-type: atomic
+ resourceFieldRef:
+ description: 'Selects a resource of the container: only
+ resources limits and requests (limits.cpu, limits.memory,
+ limits.ephemeral-storage, requests.cpu, requests.memory
+ and requests.ephemeral-storage) are currently supported.'
+ properties:
+ containerName:
+ description: 'Container name: required for volumes,
+ optional for env vars'
+ type: string
+ divisor:
+ anyOf:
+ - type: integer
+ - type: string
+ description: Specifies the output format of the
+ exposed resources, defaults to "1"
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ resource:
+ description: 'Required: resource to select'
+ type: string
+ required:
+ - resource
+ type: object
+ x-kubernetes-map-type: atomic
+ secretKeyRef:
+ description: Selects a key of a secret in the pod's
+ namespace
+ properties:
+ key:
+ description: The key of the secret to select from. Must
+ be a valid secret key.
+ type: string
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind,
+ uid?'
+ type: string
+ optional:
+ description: Specify whether the Secret or its key
+ must be defined
+ type: boolean
+ required:
+ - key
+ type: object
+ x-kubernetes-map-type: atomic
+ type: object
+ required:
+ - name
+ type: object
+ type: array
+ feAddress:
+ description: specify register fe addresses
+ properties:
+ ServiceName:
+ description: the service name that proxy fe on k8s. the service
+ must in same namespace with fe.
+ type: string
+ endpoints:
+ description: the fe addresses if not deploy by crd, user can
+ use k8s deploy fe observer.
+ properties:
+ :address:
+ description: the ip or domain array.
+ items:
+ type: string
+ type: array
+ port:
+ description: the fe port that for query. the field `query_port`
+ defines in fe config.
+ type: integer
+ type: object
+ type: object
+ hostAliases:
+ description: HostAliases is an optional list of hosts and IPs
+ that will be injected into the pod's hosts file if specified.
+ This is only valid for non-hostNetwork pods.
+ items:
+ description: HostAlias holds the mapping between IP and hostnames
+ that will be injected as an entry in the pod's hosts file.
+ properties:
+ hostnames:
+ description: Hostnames for the above IP address.
+ items:
+ type: string
+ type: array
+ ip:
+ description: IP address of the host file entry.
+ type: string
+ type: object
+ type: array
+ image:
+ description: Image for a doris cn deployment.
+ type: string
+ imagePullSecrets:
+ description: 'ImagePullSecrets is an optional list of references
+ to secrets in the same namespace to use for pulling any of the
+ images used by this PodSpec. If specified, these secrets will
+ be passed to individual puller implementations for them to use.
+ More info: https://kubernetes.io/docs/concepts/containers/images#specifying-imagepullsecrets-on-a-pod'
+ items:
+ description: LocalObjectReference contains enough information
+ to let you locate the referenced object inside the same namespace.
+ properties:
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind, uid?'
+ type: string
+ type: object
+ x-kubernetes-map-type: atomic
+ type: array
+ limits:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Limits describes the maximum amount of compute resources
+ allowed. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ nodeSelector:
+ additionalProperties:
+ type: string
+ description: (Optional) If specified, the pod's nodeSelector,displayName="Map
+ of nodeSelectors to match when scheduling pods on nodes"
+ type: object
+ persistentVolumes:
+ items:
+ description: PersistentVolume defines volume information and
+ container mount information.
+ properties:
+ annotations:
+ additionalProperties:
+ type: string
+ description: Annotation for PVC pods. Users can adapt the
+ storage authentication and pv binding of the cloud platform
+ through configuration. It only takes effect in the first
+ configuration and cannot be added or modified later.
+ type: object
+ mountPath:
+ description: the mount path for component service.
+ type: string
+ name:
+ description: the volume name associate with
+ type: string
+ persistentVolumeClaimSpec:
+ description: PersistentVolumeClaimSpec is a list of claim
+ spec about storage that pods are required.
+ properties:
+ accessModes:
+ description: 'accessModes contains the desired access
+ modes the volume should have. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#access-modes-1'
+ items:
+ type: string
+ type: array
+ dataSource:
+ properties:
+ apiGroup:
+ description: APIGroup is the group for the resource
+ being referenced. If APIGroup is not specified,
+ the specified Kind must be in the core API group.
+ For any other third-party types, APIGroup is required.
+ type: string
+ kind:
+ description: Kind is the type of resource being
+ referenced
+ type: string
+ name:
+ description: Name is the name of resource being
+ referenced
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ x-kubernetes-map-type: atomic
+ dataSourceRef:
+ properties:
+ apiGroup:
+ description: APIGroup is the group for the resource
+ being referenced. If APIGroup is not specified,
+ the specified Kind must be in the core API group.
+ For any other third-party types, APIGroup is required.
+ type: string
+ kind:
+ description: Kind is the type of resource being
+ referenced
+ type: string
+ name:
+ description: Name is the name of resource being
+ referenced
+ type: string
+ namespace:
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ resources:
+ properties:
+ claims:
+ description: "Claims lists the names of resources,
+ defined in spec.resourceClaims, that are used
+ by this container. \n This is an alpha field and
+ requires enabling the DynamicResourceAllocation
+ feature gate. \n This field is immutable."
+ items:
+ description: ResourceClaim references one entry
+ in PodSpec.ResourceClaims.
+ properties:
+ name:
+ description: Name must match the name of one
+ entry in pod.spec.resourceClaims of the
+ Pod where this field is used. It makes that
+ resource available inside a container.
+ type: string
+ required:
+ - name
+ type: object
+ type: array
+ x-kubernetes-list-map-keys:
+ - name
+ x-kubernetes-list-type: map
+ limits:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Limits describes the maximum amount
+ of compute resources allowed. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ requests:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Requests describes the minimum amount
+ of compute resources required. If Requests is
+ omitted for a container, it defaults to Limits
+ if that is explicitly specified, otherwise to
+ an implementation-defined value. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ type: object
+ selector:
+ description: selector is a label query over volumes
+ to consider for binding.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are ANDed.
+ items:
+ description: A label selector requirement is a
+ selector that contains values, a key, and an
+ operator that relates the key and values.
+ properties:
+ key:
+ description: key is the label key that the
+ selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's relationship
+ to a set of values. Valid operators are
+ In, NotIn, Exists and DoesNotExist.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ storageClassName:
+ description: 'storageClassName is the name of the StorageClass
+ required by the claim. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#class-1'
+ type: string
+ volumeMode:
+ description: volumeMode defines what type of volume
+ is required by the claim. Value of Filesystem is implied
+ when not included in claim spec.
+ type: string
+ volumeName:
+ description: volumeName is the binding reference to
+ the PersistentVolume backing this claim.
+ type: string
+ type: object
+ provisioner:
+ description: defines pvc provisioner
+ type: string
+ type: object
+ type: array
+ podLabels:
+ additionalProperties:
+ type: string
+ description: podLabels for user selector or classify pods
+ type: object
+ replicas:
+ description: Replicas is the number of desired cn Pod.
+ format: int32
+ minimum: 0
+ type: integer
+ requests:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Requests describes the minimum amount of compute
+ resources required. If Requests is omitted for a container,
+ it defaults to Limits if that is explicitly specified, otherwise
+ to an implementation-defined value. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ securityContext:
+ description: Security context for pod.
+ properties:
+ fsGroup:
+ format: int64
+ type: integer
+ fsGroupChangePolicy:
+ type: string
+ runAsGroup:
+ format: int64
+ type: integer
+ runAsNonRoot:
+ type: boolean
+ runAsUser:
+ format: int64
+ type: integer
+ seLinuxOptions:
+ properties:
+ level:
+ description: Level is SELinux level label that applies
+ to the container.
+ type: string
+ role:
+ description: Role is a SELinux role label that applies
+ to the container.
+ type: string
+ type:
+ description: Type is a SELinux type label that applies
+ to the container.
+ type: string
+ user:
+ description: User is a SELinux user label that applies
+ to the container.
+ type: string
+ type: object
+ seccompProfile:
+ description: The seccomp options to use by the containers
+ in this pod. Note that this field cannot be set when spec.os.name
+ is windows.
+ properties:
+ localhostProfile:
+ type: string
+ type:
+ type: string
+ required:
+ - type
+ type: object
+ supplementalGroups:
+ items:
+ format: int64
+ type: integer
+ type: array
+ sysctls:
+ description: Sysctls hold a list of namespaced sysctls used
+ for the pod. Pods with unsupported sysctls (by the container
+ runtime) might fail to launch. Note that this field cannot
+ be set when spec.os.name is windows.
+ items:
+ description: Sysctl defines a kernel parameter to be set
+ properties:
+ name:
+ description: Name of a property to set
+ type: string
+ value:
+ description: Value of a property to set
+ type: string
+ required:
+ - name
+ - value
+ type: object
+ type: array
+ windowsOptions:
+ description: The Windows specific settings applied to all
+ containers. If unspecified, the options within a container's
+ SecurityContext will be used. If set in both SecurityContext
+ and PodSecurityContext, the value specified in SecurityContext
+ takes precedence. Note that this field cannot be set when
+ spec.os.name is linux.
+ properties:
+ gmsaCredentialSpec:
+ description: GMSACredentialSpec is where the GMSA admission
+ webhook (https://github.com/kubernetes-sigs/windows-gmsa)
+ inlines the contents of the GMSA credential spec named
+ by the GMSACredentialSpecName field.
+ type: string
+ gmsaCredentialSpecName:
+ description: GMSACredentialSpecName is the name of the
+ GMSA credential spec to use.
+ type: string
+ hostProcess:
+ type: boolean
+ runAsUserName:
+ type: string
+ type: object
+ type: object
+ service:
+ description: 'expose doris components for accessing. example:
+ if you want to use `stream load` to load data into doris out
+ k8s, you can use be service and config different service type
+ for loading data.'
+ properties:
+ annotations:
+ additionalProperties:
+ type: string
+ description: Annotations for using function on different cloud
+ platform.
+ type: object
+ loadBalancerIP:
+ type: string
+ servicePorts:
+ description: ServicePort config service for NodePort access
+ mode.
+ items:
+ description: DorisServicePort for ServiceType=NodePort situation.
+ properties:
+ nodePort:
+ format: int32
+ type: integer
+ targetPort:
+ format: int32
+ type: integer
+ type: object
+ type: array
+ type:
+ description: 'type of service,the possible value for the service
+ type are : ClusterIP, NodePort, LoadBalancer,ExternalName.
+ More info: https://kubernetes.io/docs/concepts/services-networking/service/#publishing-services-service-types'
+ type: string
+ type: object
+ serviceAccount:
+ description: serviceAccount for cn access cloud service.
+ type: string
+ systemInitialization:
+ description: SystemInitialization for fe, be and cn setting system
+ parameters.
+ properties:
+ args:
+ description: Arguments to the entrypoint.
+ items:
+ type: string
+ type: array
+ command:
+ description: Entrypoint array. Not executed within a shell.
+ items:
+ type: string
+ type: array
+ initImage:
+ description: Image for doris initialization, default is selectdb/alpine:latest.
+ type: string
+ type: object
+ tolerations:
+ description: (Optional) Tolerations for scheduling pods onto some
+ dedicated nodes
+ items:
+ description: The pod this Toleration is attached to tolerates
+ any taint that matches the triple using
+ the matching operator .
+ properties:
+ effect:
+ description: Effect indicates the taint effect to match.
+ Empty means match all taint effects. When specified, allowed
+ values are NoSchedule, PreferNoSchedule and NoExecute.
+ type: string
+ key:
+ description: Key is the taint key that the toleration applies
+ to. Empty means match all taint keys. If the key is empty,
+ operator must be Exists; this combination means to match
+ all values and all keys.
+ type: string
+ operator:
+ type: string
+ tolerationSeconds:
+ format: int64
+ type: integer
+ value:
+ description: Value is the taint value the toleration matches
+ to. If the operator is Exists, the value should be empty,
+ otherwise just a regular string.
+ type: string
+ type: object
+ type: array
+ required:
+ - image
+ type: object
+ feSpec:
+ description: defines the fe cluster state that will be created by
+ operator.
+ properties:
+ affinity:
+ description: If specified, the pod's scheduling constraints.
+ properties:
+ nodeAffinity:
+ description: Describes node affinity scheduling rules for
+ the pod.
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ items:
+ description: An empty preferred scheduling term matches
+ all objects with implicit weight 0 (i.e. it's a no-op).
+ A null preferred scheduling term matches no objects
+ (i.e. is also a no-op).
+ properties:
+ preference:
+ description: A node selector term, associated with
+ the corresponding weight.
+ properties:
+ matchExpressions:
+ description: A list of node selector requirements
+ by node's labels.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchFields:
+ description: A list of node selector requirements
+ by node's fields.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ type: object
+ x-kubernetes-map-type: atomic
+ weight:
+ description: Weight associated with matching the
+ corresponding nodeSelectorTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - preference
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ properties:
+ nodeSelectorTerms:
+ description: Required. A list of node selector terms.
+ The terms are ORed.
+ items:
+ description: A null or empty node selector term
+ matches no objects. The requirements of them are
+ ANDed. The TopologySelectorTerm type implements
+ a subset of the NodeSelectorTerm.
+ properties:
+ matchExpressions:
+ description: A list of node selector requirements
+ by node's labels.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchFields:
+ description: A list of node selector requirements
+ by node's fields.
+ items:
+ description: A node selector requirement is
+ a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: The label key that the selector
+ applies to.
+ type: string
+ operator:
+ description: Represents a key's relationship
+ to a set of values. Valid operators
+ are In, NotIn, Exists, DoesNotExist.
+ Gt, and Lt.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ type: object
+ x-kubernetes-map-type: atomic
+ type: array
+ required:
+ - nodeSelectorTerms
+ type: object
+ x-kubernetes-map-type: atomic
+ type: object
+ podAffinity:
+ description: Describes pod affinity scheduling rules (e.g.
+ co-locate this pod in the same node, zone, etc. as some
+ other pod(s)).
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ items:
+ description: The weights of all of the matched WeightedPodAffinityTerm
+ fields are added per-node to find the most preferred
+ node(s)
+ properties:
+ podAffinityTerm:
+ description: Required. A pod affinity term, associated
+ with the corresponding weight.
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ items:
+ type: string
+ type: array
+ topologyKey:
+ type: string
+ required:
+ - topologyKey
+ type: object
+ weight:
+ description: weight associated with matching the
+ corresponding podAffinityTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - podAffinityTerm
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ items:
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ description: values is an array of string
+ values. If the operator is In or NotIn,
+ the values array must be non-empty.
+ If the operator is Exists or DoesNotExist,
+ the values array must be empty. This
+ array is replaced during a strategic
+ merge patch.
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ items:
+ type: string
+ type: array
+ topologyKey:
+ type: string
+ required:
+ - topologyKey
+ type: object
+ type: array
+ type: object
+ podAntiAffinity:
+ description: Describes pod anti-affinity scheduling rules
+ (e.g. avoid putting this pod in the same node, zone, etc.
+ as some other pod(s)).
+ properties:
+ preferredDuringSchedulingIgnoredDuringExecution:
+ items:
+ description: The weights of all of the matched WeightedPodAffinityTerm
+ fields are added per-node to find the most preferred
+ node(s)
+ properties:
+ podAffinityTerm:
+ description: Required. A pod affinity term, associated
+ with the corresponding weight.
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list
+ of label selector requirements. The requirements
+ are ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values,
+ a key, and an operator that relates
+ the key and values.
+ properties:
+ key:
+ description: key is the label key
+ that the selector applies to.
+ type: string
+ operator:
+ description: operator represents a
+ key's relationship to a set of values.
+ Valid operators are In, NotIn, Exists
+ and DoesNotExist.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ items:
+ type: string
+ type: array
+ topologyKey:
+ type: string
+ required:
+ - topologyKey
+ type: object
+ weight:
+ description: weight associated with matching the
+ corresponding podAffinityTerm, in the range 1-100.
+ format: int32
+ type: integer
+ required:
+ - podAffinityTerm
+ - weight
+ type: object
+ type: array
+ requiredDuringSchedulingIgnoredDuringExecution:
+ items:
+ properties:
+ labelSelector:
+ description: A label query over a set of resources,
+ in this case pods.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ description: A label selector requirement
+ is a selector that contains values, a key,
+ and an operator that relates the key and
+ values.
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ description: operator represents a key's
+ relationship to a set of values. Valid
+ operators are In, NotIn, Exists and
+ DoesNotExist.
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaceSelector:
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are
+ ANDed.
+ items:
+ properties:
+ key:
+ description: key is the label key that
+ the selector applies to.
+ type: string
+ operator:
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ namespaces:
+ items:
+ type: string
+ type: array
+ topologyKey:
+ type: string
+ required:
+ - topologyKey
+ type: object
+ type: array
+ type: object
+ type: object
+ annotations:
+ additionalProperties:
+ type: string
+ description: annotation for fe pods. user can config monitor annotation
+ for collect to monitor system.
+ type: object
+ claims:
+ items:
+ description: ResourceClaim references one entry in PodSpec.ResourceClaims.
+ properties:
+ name:
+ type: string
+ required:
+ - name
+ type: object
+ type: array
+ x-kubernetes-list-map-keys:
+ - name
+ x-kubernetes-list-type: map
+ configMapInfo:
+ description: the reference for cn configMap.
+ properties:
+ configMapName:
+ type: string
+ configMaps:
+ items:
+ properties:
+ configMapName:
+ description: name of configmap that needs to mount.
+ type: string
+ mountPath:
+ type: string
+ type: object
+ type: array
+ resolveKey:
+ type: string
+ type: object
+ containerSecurityContext:
+ description: Security context for all containers running in the
+ pod (unless they override it).
+ properties:
+ allowPrivilegeEscalation:
+ type: boolean
+ capabilities:
+ properties:
+ add:
+ description: Added capabilities
+ items:
+ description: Capability represent POSIX capabilities
+ type
+ type: string
+ type: array
+ drop:
+ description: Removed capabilities
+ items:
+ description: Capability represent POSIX capabilities
+ type
+ type: string
+ type: array
+ type: object
+ privileged:
+ type: boolean
+ procMount:
+ type: string
+ readOnlyRootFilesystem:
+ type: boolean
+ runAsGroup:
+ format: int64
+ type: integer
+ runAsNonRoot:
+ type: boolean
+ runAsUser:
+ format: int64
+ type: integer
+ seLinuxOptions:
+ properties:
+ level:
+ description: Level is SELinux level label that applies
+ to the container.
+ type: string
+ role:
+ description: Role is a SELinux role label that applies
+ to the container.
+ type: string
+ type:
+ description: Type is a SELinux type label that applies
+ to the container.
+ type: string
+ user:
+ description: User is a SELinux user label that applies
+ to the container.
+ type: string
+ type: object
+ seccompProfile:
+ properties:
+ localhostProfile:
+ type: string
+ type:
+ type: string
+ required:
+ - type
+ type: object
+ windowsOptions:
+ properties:
+ gmsaCredentialSpec:
+ type: string
+ gmsaCredentialSpecName:
+ description: GMSACredentialSpecName is the name of the
+ GMSA credential spec to use.
+ type: string
+ hostProcess:
+ type: boolean
+ runAsUserName:
+ type: string
+ type: object
+ type: object
+ electionNumber:
+ description: the number of fe in election. electionNumber <= replicas,
+ left as observers. default value=3
+ format: int32
+ type: integer
+ envVars:
+ description: cnEnvVars is a slice of environment variables that
+ are added to the pods, the default is empty.
+ items:
+ description: EnvVar represents an environment variable present
+ in a Container.
+ properties:
+ name:
+ description: Name of the environment variable. Must be a
+ C_IDENTIFIER.
+ type: string
+ value:
+ type: string
+ valueFrom:
+ description: Source for the environment variable's value.
+ Cannot be used if value is not empty.
+ properties:
+ configMapKeyRef:
+ description: Selects a key of a ConfigMap.
+ properties:
+ key:
+ description: The key to select.
+ type: string
+ name:
+ type: string
+ optional:
+ description: Specify whether the ConfigMap or its
+ key must be defined
+ type: boolean
+ required:
+ - key
+ type: object
+ x-kubernetes-map-type: atomic
+ fieldRef:
+ properties:
+ apiVersion:
+ description: Version of the schema the FieldPath
+ is written in terms of, defaults to "v1".
+ type: string
+ fieldPath:
+ description: Path of the field to select in the
+ specified API version.
+ type: string
+ required:
+ - fieldPath
+ type: object
+ x-kubernetes-map-type: atomic
+ resourceFieldRef:
+ properties:
+ containerName:
+ description: 'Container name: required for volumes,
+ optional for env vars'
+ type: string
+ divisor:
+ anyOf:
+ - type: integer
+ - type: string
+ description: Specifies the output format of the
+ exposed resources, defaults to "1"
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ resource:
+ description: 'Required: resource to select'
+ type: string
+ required:
+ - resource
+ type: object
+ x-kubernetes-map-type: atomic
+ secretKeyRef:
+ description: Selects a key of a secret in the pod's
+ namespace
+ properties:
+ key:
+ description: The key of the secret to select from. Must
+ be a valid secret key.
+ type: string
+ name:
+ description: 'Name of the referent. More info: https://kubernetes.io/docs/concepts/overview/working-with-objects/names/#names
+ TODO: Add other useful fields. apiVersion, kind,
+ uid?'
+ type: string
+ optional:
+ description: Specify whether the Secret or its key
+ must be defined
+ type: boolean
+ required:
+ - key
+ type: object
+ x-kubernetes-map-type: atomic
+ type: object
+ required:
+ - name
+ type: object
+ type: array
+ feAddress:
+ description: specify register fe addresses
+ properties:
+ ServiceName:
+ description: the service name that proxy fe on k8s. the service
+ must in same namespace with fe.
+ type: string
+ endpoints:
+ description: the fe addresses if not deploy by crd, user can
+ use k8s deploy fe observer.
+ properties:
+ :address:
+ description: the ip or domain array.
+ items:
+ type: string
+ type: array
+ port:
+ description: the fe port that for query. the field `query_port`
+ defines in fe config.
+ type: integer
+ type: object
+ type: object
+ hostAliases:
+ items:
+ properties:
+ hostnames:
+ description: Hostnames for the above IP address.
+ items:
+ type: string
+ type: array
+ ip:
+ description: IP address of the host file entry.
+ type: string
+ type: object
+ type: array
+ image:
+ description: Image for a doris cn deployment.
+ type: string
+ imagePullSecrets:
+ items:
+ properties:
+ name:
+ type: string
+ type: object
+ x-kubernetes-map-type: atomic
+ type: array
+ limits:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ description: 'Limits describes the maximum amount of compute resources
+ allowed. More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/'
+ type: object
+ nodeSelector:
+ additionalProperties:
+ type: string
+ description: (Optional) If specified, the pod's nodeSelector,displayName="Map
+ of nodeSelectors to match when scheduling pods on nodes"
+ type: object
+ persistentVolumes:
+ items:
+ description: PersistentVolume defines volume information and
+ container mount information.
+ properties:
+ annotations:
+ additionalProperties:
+ type: string
+ type: object
+ mountPath:
+ description: the mount path for component service.
+ type: string
+ name:
+ description: the volume name associate with
+ type: string
+ persistentVolumeClaimSpec:
+ description: PersistentVolumeClaimSpec is a list of claim
+ spec about storage that pods are required.
+ properties:
+ accessModes:
+ items:
+ type: string
+ type: array
+ dataSource:
+ properties:
+ apiGroup:
+ type: string
+ kind:
+ description: Kind is the type of resource being
+ referenced
+ type: string
+ name:
+ description: Name is the name of resource being
+ referenced
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ x-kubernetes-map-type: atomic
+ dataSourceRef:
+ properties:
+ apiGroup:
+ type: string
+ kind:
+ description: Kind is the type of resource being
+ referenced
+ type: string
+ name:
+ description: Name is the name of resource being
+ referenced
+ type: string
+ namespace:
+ type: string
+ required:
+ - kind
+ - name
+ type: object
+ resources:
+ properties:
+ claims:
+ items:
+ description: ResourceClaim references one entry
+ in PodSpec.ResourceClaims.
+ properties:
+ name:
+ type: string
+ required:
+ - name
+ type: object
+ type: array
+ x-kubernetes-list-map-keys:
+ - name
+ x-kubernetes-list-type: map
+ limits:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ type: object
+ requests:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ type: object
+ type: object
+ selector:
+ description: selector is a label query over volumes
+ to consider for binding.
+ properties:
+ matchExpressions:
+ description: matchExpressions is a list of label
+ selector requirements. The requirements are ANDed.
+ items:
+ properties:
+ key:
+ description: key is the label key that the
+ selector applies to.
+ type: string
+ operator:
+ type: string
+ values:
+ items:
+ type: string
+ type: array
+ required:
+ - key
+ - operator
+ type: object
+ type: array
+ matchLabels:
+ additionalProperties:
+ type: string
+ type: object
+ type: object
+ x-kubernetes-map-type: atomic
+ storageClassName:
+ description: 'storageClassName is the name of the StorageClass
+ required by the claim. More info: https://kubernetes.io/docs/concepts/storage/persistent-volumes#class-1'
+ type: string
+ volumeMode:
+ description: volumeMode defines what type of volume
+ is required by the claim. Value of Filesystem is implied
+ when not included in claim spec.
+ type: string
+ volumeName:
+ description: volumeName is the binding reference to
+ the PersistentVolume backing this claim.
+ type: string
+ type: object
+ provisioner:
+ description: defines pvc provisioner
+ type: string
+ type: object
+ type: array
+ podLabels:
+ additionalProperties:
+ type: string
+ description: podLabels for user selector or classify pods
+ type: object
+ replicas:
+ description: Replicas is the number of desired cn Pod.
+ format: int32
+ minimum: 0
+ type: integer
+ requests:
+ additionalProperties:
+ anyOf:
+ - type: integer
+ - type: string
+ pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$
+ x-kubernetes-int-or-string: true
+ type: object
+ securityContext:
+ description: Security context for pod.
+ properties:
+ fsGroup:
+ format: int64
+ type: integer
+ fsGroupChangePolicy:
+ type: string
+ runAsGroup:
+ format: int64
+ type: integer
+ runAsNonRoot:
+ type: boolean
+ runAsUser:
+ format: int64
+ type: integer
+ seLinuxOptions:
+ properties:
+ level:
+ description: Level is SELinux level label that applies
+ to the container.
+ type: string
+ role:
+ description: Role is a SELinux role label that applies
+ to the container.
+ type: string
+ type:
+ description: Type is a SELinux type label that applies
+ to the container.
+ type: string
+ user:
+ description: User is a SELinux user label that applies
+ to the container.
+ type: string
+ type: object
+ seccompProfile:
+ description: The seccomp options to use by the containers
+ in this pod. Note that this field cannot be set when spec.os.name
+ is windows.
+ properties:
+ localhostProfile:
+ type: string
+ type:
+ type: string
+ required:
+ - type
+ type: object
+ supplementalGroups:
+ items:
+ format: int64
+ type: integer
+ type: array
+ sysctls:
+ description: Sysctls hold a list of namespaced sysctls used
+ for the pod. Pods with unsupported sysctls (by the container
+ runtime) might fail to launch. Note that this field cannot
+ be set when spec.os.name is windows.
+ items:
+ description: Sysctl defines a kernel parameter to be set
+ properties:
+ name:
+ description: Name of a property to set
+ type: string
+ value:
+ description: Value of a property to set
+ type: string
+ required:
+ - name
+ - value
+ type: object
+ type: array
+ windowsOptions:
+ properties:
+ gmsaCredentialSpec:
+ type: string
+ gmsaCredentialSpecName:
+ description: GMSACredentialSpecName is the name of the
+ GMSA credential spec to use.
+ type: string
+ hostProcess:
+ type: boolean
+ runAsUserName:
+ type: string
+ type: object
+ type: object
+ service:
+ properties:
+ annotations:
+ additionalProperties:
+ type: string
+ description: Annotations for using function on different cloud
+ platform.
+ type: object
+ loadBalancerIP:
+ type: string
+ servicePorts:
+ description: ServicePort config service for NodePort access
+ mode.
+ items:
+ description: DorisServicePort for ServiceType=NodePort situation.
+ properties:
+ nodePort:
+ format: int32
+ type: integer
+ targetPort:
+ format: int32
+ type: integer
+ type: object
+ type: array
+ type:
+ type: string
+ type: object
+ serviceAccount:
+ description: serviceAccount for cn access cloud service.
+ type: string
+ systemInitialization:
+ description: SystemInitialization for fe, be and cn setting system
+ parameters.
+ properties:
+ args:
+ description: Arguments to the entrypoint.
+ items:
+ type: string
+ type: array
+ command:
+ description: Entrypoint array. Not executed within a shell.
+ items:
+ type: string
+ type: array
+ initImage:
+ description: Image for doris initialization, default is selectdb/alpine:latest.
+ type: string
+ type: object
+ tolerations:
+ description: (Optional) Tolerations for scheduling pods onto some
+ dedicated nodes
+ items:
+ description: The pod this Toleration is attached to tolerates
+ any taint that matches the triple using
+ the matching operator .
+ properties:
+ effect:
+ description: Effect indicates the taint effect to match.
+ Empty means match all taint effects. When specified, allowed
+ values are NoSchedule, PreferNoSchedule and NoExecute.
+ type: string
+ key:
+ description: Key is the taint key that the toleration applies
+ to. Empty means match all taint keys. If the key is empty,
+ operator must be Exists; this combination means to match
+ all values and all keys.
+ type: string
+ operator:
+ description: Operator represents a key's relationship to
+ the value. Valid operators are Exists and Equal. Defaults
+ to Equal. Exists is equivalent to wildcard for value,
+ so that a pod can tolerate all taints of a particular
+ category.
+ type: string
+ tolerationSeconds:
+ description: TolerationSeconds represents the period of
+ time the toleration (which must be of effect NoExecute,
+ otherwise this field is ignored) tolerates the taint.
+ By default, it is not set, which means tolerate the taint
+ forever (do not evict). Zero and negative values will
+ be treated as 0 (evict immediately) by the system.
+ format: int64
+ type: integer
+ value:
+ description: Value is the taint value the toleration matches
+ to. If the operator is Exists, the value should be empty,
+ otherwise just a regular string.
+ type: string
+ type: object
+ type: array
+ required:
+ - image
+ type: object
+ type: object
+ status:
+ description: DorisClusterStatus defines the observed state of DorisCluster
+ properties:
+ beStatus:
+ description: describe be cluster status, recode running, creating
+ and failed pods.
+ properties:
+ accessService:
+ description: DorisComponentStatus represents the status of a doris
+ component. the name of fe service exposed for user.
+ type: string
+ componentCondition:
+ properties:
+ lastTransitionTime:
+ description: The last time this condition was updated.
+ format: date-time
+ type: string
+ message:
+ description: A human readable message indicating details about
+ the transition.
+ type: string
+ phase:
+ description: Phase of statefulset condition.
+ type: string
+ reason:
+ description: The reason for the condition's last transition.
+ type: string
+ subResourceName:
+ type: string
+ required:
+ - lastTransitionTime
+ - message
+ - phase
+ - reason
+ type: object
+ creatingInstances:
+ description: CreatingInstances in creating pod names.
+ items:
+ type: string
+ type: array
+ failedInstances:
+ description: FailedInstances failed pod names.
+ items:
+ type: string
+ type: array
+ runningInstances:
+ description: RunningInstances in running status pod names.
+ items:
+ type: string
+ type: array
+ required:
+ - componentCondition
+ type: object
+ brokerStatus:
+ description: describe broker cluster status, record running, creating
+ and failed pods.
+ properties:
+ accessService:
+ description: DorisComponentStatus represents the status of a doris
+ component. the name of fe service exposed for user.
+ type: string
+ componentCondition:
+ properties:
+ lastTransitionTime:
+ description: The last time this condition was updated.
+ format: date-time
+ type: string
+ message:
+ description: A human readable message indicating details about
+ the transition.
+ type: string
+ phase:
+ description: Phase of statefulset condition.
+ type: string
+ reason:
+ description: The reason for the condition's last transition.
+ type: string
+ subResourceName:
+ type: string
+ required:
+ - lastTransitionTime
+ - message
+ - phase
+ - reason
+ type: object
+ creatingInstances:
+ description: CreatingInstances in creating pod names.
+ items:
+ type: string
+ type: array
+ failedInstances:
+ description: FailedInstances failed pod names.
+ items:
+ type: string
+ type: array
+ runningInstances:
+ description: RunningInstances in running status pod names.
+ items:
+ type: string
+ type: array
+ required:
+ - componentCondition
+ type: object
+ cnStatus:
+ description: describe cn cluster status, record running, creating
+ and failed pods.
+ properties:
+ accessService:
+ description: DorisComponentStatus represents the status of a doris
+ component. the name of fe service exposed for user.
+ type: string
+ componentCondition:
+ properties:
+ lastTransitionTime:
+ description: The last time this condition was updated.
+ format: date-time
+ type: string
+ message:
+ description: A human readable message indicating details about
+ the transition.
+ type: string
+ phase:
+ description: Phase of statefulset condition.
+ type: string
+ reason:
+ description: The reason for the condition's last transition.
+ type: string
+ subResourceName:
+ type: string
+ required:
+ - lastTransitionTime
+ - message
+ - phase
+ - reason
+ type: object
+ creatingInstances:
+ description: CreatingInstances in creating pod names.
+ items:
+ type: string
+ type: array
+ failedInstances:
+ description: FailedInstances failed pod names.
+ items:
+ type: string
+ type: array
+ horizontalScaler:
+ description: HorizontalAutoscaler have the autoscaler information.
+ properties:
+ name:
+ description: the deploy horizontal scaler name
+ type: string
+ version:
+ description: the deploy horizontal version.
+ type: string
+ type: object
+ runningInstances:
+ description: RunningInstances in running status pod names.
+ items:
+ type: string
+ type: array
+ required:
+ - componentCondition
+ type: object
+ feStatus:
+ description: describe fe cluster status, record running, creating
+ and failed pods.
+ properties:
+ accessService:
+ description: DorisComponentStatus represents the status of a doris
+ component. the name of fe service exposed for user.
+ type: string
+ componentCondition:
+ properties:
+ lastTransitionTime:
+ description: The last time this condition was updated.
+ format: date-time
+ type: string
+ message:
+ description: A human readable message indicating details about
+ the transition.
+ type: string
+ phase:
+ description: Phase of statefulset condition.
+ type: string
+ reason:
+ description: The reason for the condition's last transition.
+ type: string
+ subResourceName:
+ type: string
+ required:
+ - lastTransitionTime
+ - message
+ - phase
+ - reason
+ type: object
+ creatingInstances:
+ description: CreatingInstances in creating pod names.
+ items:
+ type: string
+ type: array
+ failedInstances:
+ description: FailedInstances failed pod names.
+ items:
+ type: string
+ type: array
+ runningInstances:
+ description: RunningInstances in running status pod names.
+ items:
+ type: string
+ type: array
+ required:
+ - componentCondition
+ type: object
+ type: object
+ type: object
+ served: true
+ storage: true
+ subresources:
+ status: {}
diff --git a/agent-common/SplitProject/监管平台-Doris-集群部署/doris-operator.yaml b/agent-common/SplitProject/监管平台-Doris-集群部署/doris-operator.yaml
new file mode 100644
index 0000000..5973a25
--- /dev/null
+++ b/agent-common/SplitProject/监管平台-Doris-集群部署/doris-operator.yaml
@@ -0,0 +1,347 @@
+# Source: doris-operator/templates/serviceaccount.yaml
+apiVersion: v1
+kind: ServiceAccount
+metadata:
+ labels:
+ app.kubernetes.io/name: serviceaccount
+ app.kubernetes.io/instance: controller-doris-operator-sa
+ app.kubernetes.io/component: rbac
+ app.kubernetes.io/created-by: doris-operator
+ app.kubernetes.io/part-of: doris-operator
+ app.kubernetes.io/managed-by: Helm
+ name: doris-operator
+ namespace: doriscluster
+---
+# Source: doris-operator/templates/clusterrole.yaml
+apiVersion: rbac.authorization.k8s.io/v1
+kind: ClusterRole
+metadata:
+ creationTimestamp: null
+ name: doris-operator
+rules:
+ - apiGroups:
+ - apps
+ resources:
+ - statefulsets
+ verbs:
+ - create
+ - delete
+ - get
+ - list
+ - patch
+ - update
+ - watch
+ - apiGroups:
+ - apps
+ resources:
+ - statefulsets/status
+ verbs:
+ - get
+ - apiGroups:
+ - autoscaling
+ resources:
+ - horizontalpodautoscalers
+ verbs:
+ - create
+ - delete
+ - get
+ - list
+ - patch
+ - update
+ - watch
+ - apiGroups:
+ - ""
+ resources:
+ - configmaps
+ verbs:
+ - get
+ - list
+ - watch
+ - apiGroups:
+ - ""
+ resources:
+ - endpoints
+ verbs:
+ - get
+ - list
+ - watch
+ - apiGroups:
+ - ""
+ resources:
+ - pods
+ verbs:
+ - get
+ - list
+ - watch
+ - apiGroups:
+ - ""
+ resources:
+ - persistentvolumeclaims
+ verbs:
+ - get
+ - list
+ - watch
+ - update
+ - patch
+ - apiGroups:
+ - ""
+ resources:
+ - secrets
+ verbs:
+ - get
+ - list
+ - watch
+ - apiGroups:
+ - ""
+ resources:
+ - serviceaccounts
+ verbs:
+ - create
+ - delete
+ - get
+ - list
+ - patch
+ - update
+ - watch
+ - apiGroups:
+ - ""
+ resources:
+ - services
+ verbs:
+ - create
+ - delete
+ - get
+ - list
+ - patch
+ - update
+ - watch
+ - apiGroups:
+ - doris.selectdb.com
+ resources:
+ - dorisclusters
+ verbs:
+ - create
+ - delete
+ - get
+ - list
+ - patch
+ - update
+ - watch
+ - apiGroups:
+ - doris.selectdb.com
+ resources:
+ - dorisclusters/finalizers
+ verbs:
+ - update
+ - apiGroups:
+ - doris.selectdb.com
+ resources:
+ - dorisclusters/status
+ verbs:
+ - get
+ - patch
+ - update
+ - apiGroups:
+ - rbac.authorization.k8s.io
+ resources:
+ - clusterrolebindings
+ verbs:
+ - create
+ - delete
+ - get
+ - list
+ - patch
+ - update
+ - watch
+ - apiGroups:
+ - rbac.authorization.k8s.io
+ resources:
+ - rolebindings
+ verbs:
+ - create
+ - delete
+ - get
+ - list
+ - patch
+ - update
+ - watch
+---
+# Source: doris-operator/templates/clusterrolebinding.yaml
+apiVersion: rbac.authorization.k8s.io/v1
+kind: ClusterRoleBinding
+metadata:
+ labels:
+ app.kubernetes.io/name: clusterrolebinding
+ app.kubernetes.io/instance: doris-operator-rolebinding
+ app.kubernetes.io/component: rbac
+ app.kubernetes.io/created-by: doris-operator
+ app.kubernetes.io/part-of: doris-operator
+ app.kubernetes.io/managed-by: Helm
+ name: doris-operator-rolebinding
+roleRef:
+ apiGroup: rbac.authorization.k8s.io
+ kind: ClusterRole
+ name: doris-operator
+subjects:
+ - kind: ServiceAccount
+ name: doris-operator
+ namespace: doriscluster
+---
+# Source: doris-operator/templates/leader-election-role.yaml
+apiVersion: rbac.authorization.k8s.io/v1
+kind: Role
+metadata:
+ labels:
+ app.kubernetes.io/name: role
+ app.kubernetes.io/instance: leader-election-role
+ app.kubernetes.io/component: rbac
+ app.kubernetes.io/created-by: doris-operator
+ app.kubernetes.io/part-of: doris-operator
+ app.kubernetes.io/managed-by: Helm
+ name: leader-election-role
+ namespace: doriscluster
+rules:
+ - apiGroups:
+ - ""
+ resources:
+ - configmaps
+ verbs:
+ - get
+ - list
+ - watch
+ - create
+ - update
+ - patch
+ - delete
+ - apiGroups:
+ - coordination.k8s.io
+ resources:
+ - leases
+ verbs:
+ - get
+ - list
+ - watch
+ - create
+ - update
+ - patch
+ - delete
+ - apiGroups:
+ - ""
+ resources:
+ - events
+ verbs:
+ - create
+ - patch
+---
+# Source: doris-operator/templates/leader-election-role-binding.yaml
+apiVersion: rbac.authorization.k8s.io/v1
+kind: RoleBinding
+metadata:
+ labels:
+ app.kubernetes.io/name: rolebinding
+ app.kubernetes.io/instance: leader-election-rolebinding
+ app.kubernetes.io/component: rbac
+ app.kubernetes.io/created-by: doris-operator
+ app.kubernetes.io/part-of: doris-operator
+ app.kubernetes.io/managed-by: Helm
+ name: leader-election-rolebinding
+ namespace: doriscluster
+roleRef:
+ apiGroup: rbac.authorization.k8s.io
+ kind: Role
+ name: leader-election-role
+subjects:
+ - kind: ServiceAccount
+ name: doris-operator
+ namespace: doriscluster
+---
+# Source: doris-operator/templates/deployment.yaml
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: doris-operator
+ namespace: doriscluster
+ labels:
+ control-plane: doris-operator
+ app.kubernetes.io/name: deployment
+ app.kubernetes.io/instance: doris-operator
+ app.kubernetes.io/component: doris-operator
+ app.kubernetes.io/created-by: doris-operator
+ app.kubernetes.io/part-of: doris-operator
+spec:
+ selector:
+ matchLabels:
+ control-plane: doris-operator
+ replicas: 1
+ template:
+ metadata:
+ annotations:
+ kubectl.kubernetes.io/default-container: doris-operator
+ labels:
+ control-plane: doris-operator
+ spec:
+ # TODO(user): Uncomment the following code to configure the nodeAffinity expression
+ # according to the platforms which are supported by your solution.
+ # It is considered best practice to support multiple architectures. You can
+ # build your manager image using the makefile target docker-buildx.
+ # affinity:
+ # nodeAffinity:
+ # requiredDuringSchedulingIgnoredDuringExecution:
+ # nodeSelectorTerms:
+ # - matchExpressions:
+ # - key: kubernetes.io/arch
+ # operator: In
+ # values:
+ # - amd64
+ # - arm64
+ # - ppc64le
+ # - s390x
+ # - key: kubernetes.io/os
+ # operator: In
+ # values:
+ # - linux
+ securityContext:
+ runAsNonRoot: true
+ # TODO(user): For common cases that do not require escalating privileges
+ # it is recommended to ensure that all your Pods/Containers are restrictive.
+ # More info: https://kubernetes.io/docs/concepts/security/pod-security-standards/#restricted
+ # Please uncomment the following code if your project does NOT have to work on old Kubernetes
+ # versions < 1.19 or on vendors versions which do NOT support this field by default (i.e. Openshift < 4.11 ).
+ # seccompProfile:
+ # type: RuntimeDefault
+ containers:
+ - command:
+ - /dorisoperator
+ args:
+ - --leader-elect
+ image: harbor.cdcyy.com.cn/cmii/doris.k8s-operator:1.3.1
+ name: dorisoperator
+ securityContext:
+ allowPrivilegeEscalation: false
+ capabilities:
+ drop:
+ - "ALL"
+ livenessProbe:
+ httpGet:
+ path: /healthz
+ port: 8081
+ initialDelaySeconds: 15
+ periodSeconds: 20
+ readinessProbe:
+ httpGet:
+ path: /readyz
+ port: 8081
+ initialDelaySeconds: 5
+ periodSeconds: 10
+ # TODO(user): Configure the resources accordingly based on the project requirements.
+ # More info: https://kubernetes.io/docs/concepts/configuration/manage-resources-containers/
+ resources:
+ requests:
+ cpu: 2
+ memory: 4Gi
+ limits:
+ cpu: 2
+ memory: 4Gi
+ serviceAccountName: doris-operator
+ terminationGracePeriodSeconds: 10
+
diff --git a/agent-common/real_project/cmii-uavms-pyfusion.yaml b/agent-common/real_project/cmii-uavms-pyfusion.yaml
new file mode 100644
index 0000000..c2dc898
--- /dev/null
+++ b/agent-common/real_project/cmii-uavms-pyfusion.yaml
@@ -0,0 +1,138 @@
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: pyfusion-configmap
+ namespace: uavcloud-devflight
+data:
+ config.yaml: |-
+ mqtt:
+ broker: "helm-emqxs"
+ port: 1883
+ username: "cmlc"
+ password: "4YPk*DS%+5"
+
+ topics:
+ mqtt_topic: "bridge/DP74b4ef9fb4aaf269/device_data/FU_PAM/+"
+ sensor_topic: "fromcheck/DP74b4ef9fb4aaf269/device_data/FU_PAM/+"
+---
+kind: Deployment
+apiVersion: apps/v1
+metadata:
+ name: cmii-uavms-pyfusion
+ namespace: uavcloud-devflight
+ labels:
+ app.kubernetes.io/app-version: 6.2.0
+ app.kubernetes.io/managed-by: octopus-control
+ cmii.app: cmii-uavms-pyfusion
+ cmii.type: backend
+ octopus/control: backend-app-1.0.0
+spec:
+ replicas: 1
+ selector:
+ matchLabels:
+ cmii.app: cmii-uavms-pyfusion
+ cmii.type: backend
+ template:
+ metadata:
+ creationTimestamp: null
+ labels:
+ cmii.app: cmii-uavms-pyfusion
+ cmii.type: backend
+ spec:
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+ - name: pyfusion-conf
+ configMap:
+ name: pyfusion-configmap
+ items:
+ - key: config.yaml
+ path: config.yaml
+ containers:
+ - name: cmii-uavms-pyfusion
+ image: 'harbor.cdcyy.com.cn/cmii/cmii-uavms-pyfusion:6.2.0'
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ env:
+ - name: VERSION
+ value: 6.2.0
+ - name: NACOS_SYSTEM_CONFIG_NAME
+ value: cmii-backend-system
+ - name: NACOS_SERVICE_CONFIG_NAME
+ value: cmii-uavms-pyfusion
+ - name: NACOS_SERVER_ADDRESS
+ value: 'helm-nacos:8848'
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uavms-pyfusion
+ - name: NACOS_DISCOVERY_PORT
+ value: '8080'
+ - name: BIZ_CONFIG_GROUP
+ value: 6.2.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.2.0
+ - name: IMAGE_VERSION
+ value: 6.2.0
+ resources:
+ limits:
+ cpu: '2'
+ memory: 3Gi
+ requests:
+ cpu: 200m
+ memory: 500Mi
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ subPath: uavcloud-devflight/cmii-uavms-pyfusion
+ - name: pyfusion-conf
+ mountPath: /app/config.yaml
+ subPath: config.yaml
+ terminationMessagePath: /dev/termination-log
+ terminationMessagePolicy: File
+ imagePullPolicy: Always
+ restartPolicy: Always
+ terminationGracePeriodSeconds: 30
+ dnsPolicy: ClusterFirst
+ securityContext: { }
+ imagePullSecrets:
+ - name: harborsecret
+ affinity: { }
+ schedulerName: default-scheduler
+ strategy:
+ type: RollingUpdate
+ rollingUpdate:
+ maxUnavailable: 1
+ maxSurge: 25%
+ revisionHistoryLimit: 10
+ progressDeadlineSeconds: 600
+---
+kind: Service
+apiVersion: v1
+metadata:
+ name: cmii-uavms-pyfusion
+ namespace: uavcloud-devflight
+ labels:
+ app.kubernetes.io/app-version: 6.2.0
+ app.kubernetes.io/managed-by: octopus-control
+ cmii.app: cmii-uavms-pyfusion
+ cmii.type: backend
+ octopus/control: backend-app-1.0.0
+spec:
+ ports:
+ - name: backend-tcp
+ protocol: TCP
+ port: 8080
+ targetPort: 8080
+ selector:
+ cmii.app: cmii-uavms-pyfusion
+ cmii.type: backend
+ type: ClusterIP
+ sessionAffinity: None
+
+
+
diff --git a/agent-common/real_project/uavcloud-devflight/k8s-backend.yaml b/agent-common/real_project/uavcloud-devflight/k8s-backend.yaml
index 2532b83..8f6a094 100644
--- a/agent-common/real_project/uavcloud-devflight/k8s-backend.yaml
+++ b/agent-common/real_project/uavcloud-devflight/k8s-backend.yaml
@@ -2,11 +2,11 @@
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-grid-datasource
+ name: cmii-uav-tower
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-tower
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -18,12 +18,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-tower
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-tower
spec:
affinity:
nodeAffinity:
@@ -37,14 +37,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-grid-datasource
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-grid-datasource:6.0.0
+ - name: cmii-uav-tower
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-tower:6.0.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-grid-datasource
+ value: cmii-uav-tower
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -110,7 +110,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-grid-datasource
+ subPath: uavcloud-devflight/cmii-uav-tower
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -119,11 +119,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-grid-datasource
+ name: cmii-uav-tower
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-tower
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -131,1397 +131,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-surveillance
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-surveillance
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-surveillance:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-surveillance
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-surveillance
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-surveillance
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-brain
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-brain
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-brain
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-brain
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-brain
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-brain:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-brain
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-brain
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-brain
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-brain
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-brain
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-multilink
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-multilink
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-multilink:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-multilink
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-multilink
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-multilink
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-advanced5g
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-advanced5g
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-advanced5g:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-advanced5g
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-advanced5g
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-advanced5g
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-iot-dispatcher
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-iot-dispatcher
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-iot-dispatcher:6.1.0-v5
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-iot-dispatcher
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-iot-dispatcher
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-iot-dispatcher
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-grid-engine
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-grid-engine
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-grid-engine:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-grid-engine
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-grid-engine
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-grid-engine
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uas-lifecycle
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uas-lifecycle
- image: harbor.cdcyy.com.cn/cmii/cmii-uas-lifecycle:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uas-lifecycle
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uas-lifecycle
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uas-lifecycle
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-emergency
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-emergency
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-emergency
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-emergency
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-emergency
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-emergency:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-emergency
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-emergency
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-emergency
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-emergency
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-emergency
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-data-post-process
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-data-post-process
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-data-post-process:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-data-post-process
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-data-post-process
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-data-post-process
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: helm-live-op-v2
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: helm-live-op-v2
- image: harbor.cdcyy.com.cn/cmii/helm-live-op-v2:5.2.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: helm-live-op-v2
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/helm-live-op-v2
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: helm-live-op-v2
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: helm-live-op-v2
+ cmii.app: cmii-uav-tower
ports:
- name: backend-tcp
port: 8080
@@ -1669,2786 +279,6 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
-metadata:
- name: cmii-uav-mission
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-mission
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-mission:5.7.0-szga
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-mission
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-mission
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-mission
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-device
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-device
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-device
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-device
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-device
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-device:5.7.0-szga
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-device
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-device
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-device
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-device
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-device
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-process
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-process
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-process
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-process
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-process
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-process:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-process
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-process
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-process
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-process
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-process
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-clusters
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-clusters
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-clusters:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-clusters
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-clusters
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-clusters
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-sync
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-sync
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-sync:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-sync
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-sync
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-sync
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-oauth
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-oauth
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-oauth:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-oauth
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-oauth
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-oauth
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-airspace
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-airspace
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-airspace
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-airspace
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-airspace
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-airspace:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-airspace
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-airspace
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-airspace
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-airspace
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-airspace
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-autowaypoint
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-autowaypoint
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-autowaypoint:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-autowaypoint
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-autowaypoint
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-autowaypoint
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-cms
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cms
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-cms
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cms
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-cms
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-cms:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-cms
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-cms
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-cms
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cms
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-cms
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-kpi-monitor
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-kpi-monitor
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-kpi-monitor:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-kpi-monitor
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-kpi-monitor
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-kpi-monitor
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-alarm
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-alarm
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-alarm
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-alarm
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-alarm
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-alarm:6.2.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-alarm
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-alarm
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-alarm
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-alarm
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-alarm
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-container-scanner-go
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-container-scanner-go
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-container-scanner-go:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-container-scanner-go
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-container-scanner-go
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-container-scanner-go
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-blockchain
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-blockchain
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-blockchain
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-blockchain
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-blockchain
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-blockchain:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-blockchain
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-blockchain
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-blockchain
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-blockchain
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-blockchain
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-mqtthandler
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-mqtthandler
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-mqtthandler:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-mqtthandler
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-mqtthandler
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-mqtthandler
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-user
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-user
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-user
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-user
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-user
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-user:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-user
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-user
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-user
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-user
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-user
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-logger
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-logger
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-logger:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-logger
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-logger
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-logger
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-cloud-live
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-cloud-live
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-cloud-live:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-cloud-live
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-cloud-live
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-cloud-live
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-waypoint
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-waypoint
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-waypoint:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-waypoint
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-waypoint
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-waypoint
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: uav-auth-backend
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: uav-auth-backend
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: uav-auth-backend
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: uav-auth-backend
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: uav-auth-backend
- image: harbor.cdcyy.com.cn/cmii/uav-auth-backend:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: uav-auth-backend
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/uav-auth-backend
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: uav-auth-backend
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: uav-auth-backend
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: uav-auth-backend
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-depotautoreturn
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-depotautoreturn
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-depotautoreturn:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-depotautoreturn
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-depotautoreturn
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-depotautoreturn
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
metadata:
name: cmii-uas-gateway
namespace: uavcloud-devflight
@@ -4486,7 +316,7 @@ spec:
- name: harborsecret
containers:
- name: cmii-uas-gateway
- image: harbor.cdcyy.com.cn/cmii/cmii-uas-gateway:6.0.0
+ image: harbor.cdcyy.com.cn/cmii/cmii-uas-gateway:6.0.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
@@ -4588,2647 +418,6 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
-metadata:
- name: cmii-admin-user
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-user
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-admin-user
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-user
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-admin-user
- image: harbor.cdcyy.com.cn/cmii/cmii-admin-user:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-admin-user
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-admin-user
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-admin-user
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-user
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-admin-user
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-sky-converge
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-sky-converge
- image: harbor.cdcyy.com.cn/cmii/cmii-sky-converge:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-sky-converge
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-sky-converge
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-sky-converge
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-suav-supervision
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-suav-supervision
- image: harbor.cdcyy.com.cn/cmii/cmii-suav-supervision:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-suav-supervision
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-suav-supervision
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-suav-supervision
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uavms-security-center
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uavms-security-center
- image: harbor.cdcyy.com.cn/cmii/cmii-uavms-security-center:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uavms-security-center
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uavms-security-center
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uavms-security-center
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-container-scanner
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-container-scanner
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-container-scanner:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-container-scanner
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-container-scanner
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-container-scanner
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-notice
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-notice
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-notice:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-notice
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-notice
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-notice
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-tower
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-tower
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-tower:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-tower
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-tower
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-tower
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-gis-server
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-gis-server
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-gis-server
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-gis-server
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-gis-server
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-gis-server:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-gis-server
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-gis-server
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-gis-server
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-gis-server
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-gis-server
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-sense-adapter
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-sense-adapter
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-sense-adapter:6.2.0-25021802
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-sense-adapter
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-sense-adapter
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-sense-adapter
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-open-gateway
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-open-gateway
- image: harbor.cdcyy.com.cn/cmii/cmii-open-gateway:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-open-gateway
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-open-gateway
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-open-gateway
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-integration
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-integration
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-integration
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-integration
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-integration
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-integration:5.7.0-szga
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-integration
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-integration
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-integration
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-integration
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-integration
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-admin-data
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-data
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-admin-data
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-data
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-admin-data
- image: harbor.cdcyy.com.cn/cmii/cmii-admin-data:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-admin-data
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-admin-data
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-admin-data
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-data
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-admin-data
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: uav-secret-backend
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: uav-secret-backend
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: uav-secret-backend
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: uav-secret-backend
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: uav-secret-backend
- image: harbor.cdcyy.com.cn/cmii/uav-secret-backend:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: uav-secret-backend
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/uav-secret-backend
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: uav-secret-backend
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: uav-secret-backend
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: uav-secret-backend
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-gateway
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-gateway
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-gateway
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-gateway
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-gateway
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-gateway:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-gateway
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-gateway
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-gateway
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-gateway
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-gateway
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-bridge
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-bridge
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-bridge
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-bridge
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-bridge
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-bridge:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-bridge
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-bridge
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-bridge
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-bridge
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-bridge
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-industrial-portfolio
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-industrial-portfolio
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-industrial-portfolio:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-industrial-portfolio
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-industrial-portfolio
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-industrial-portfolio
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-security-trace
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-security-trace
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-security-trace:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-security-trace
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-security-trace
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-security-trace
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-developer
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-developer
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-developer:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-developer
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-developer
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-developer
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-sec-awareness
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-sec-awareness
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-sec-awareness:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-sec-awareness
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-sec-awareness
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-sec-awareness
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
metadata:
name: cmii-uav-fwdd
namespace: uavcloud-devflight
@@ -7369,150 +558,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-app-release
+ name: cmii-uav-emergency
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-app-release
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-app-release
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-app-release
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-app-release
- image: harbor.cdcyy.com.cn/cmii/cmii-app-release:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-app-release
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-app-release
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-app-release
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-app-release
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-app-release
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-data-classification
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-emergency
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7524,12 +574,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-emergency
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-emergency
spec:
affinity:
nodeAffinity:
@@ -7543,14 +593,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-data-classification
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-data-classification:5.7.0-snapshot
+ - name: cmii-uav-emergency
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-emergency:6.0.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-data-classification
+ value: cmii-uav-emergency
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -7616,7 +666,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-data-classification
+ subPath: uavcloud-devflight/cmii-uav-emergency
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -7625,11 +675,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-data-classification
+ name: cmii-uav-emergency
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-emergency
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7637,7 +687,424 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-emergency
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-sense-adapter
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-sense-adapter
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-sense-adapter:6.2.0-25021802
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-sense-adapter
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-sense-adapter
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-sense-adapter
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-waypoint
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-waypoint
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-waypoint:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-waypoint
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-waypoint
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-waypoint
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-advanced5g
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-advanced5g
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-advanced5g
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-advanced5g
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-advanced5g
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-advanced5g:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-advanced5g
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-advanced5g
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-advanced5g
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-advanced5g
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-advanced5g
ports:
- name: backend-tcp
port: 8080
@@ -7786,11 +1253,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-admin-gateway
+ name: cmii-sky-converge
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-sky-converge
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7802,12 +1269,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-sky-converge
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-sky-converge
spec:
affinity:
nodeAffinity:
@@ -7821,14 +1288,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-admin-gateway
- image: harbor.cdcyy.com.cn/cmii/cmii-admin-gateway:6.0.0
+ - name: cmii-sky-converge
+ image: harbor.cdcyy.com.cn/cmii/cmii-sky-converge:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-admin-gateway
+ value: cmii-sky-converge
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -7894,7 +1361,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-admin-gateway
+ subPath: uavcloud-devflight/cmii-sky-converge
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -7903,11 +1370,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-admin-gateway
+ name: cmii-sky-converge
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-sky-converge
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7915,7 +1382,5011 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-sky-converge
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-depotautoreturn
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-depotautoreturn
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-depotautoreturn:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-depotautoreturn
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-depotautoreturn
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-depotautoreturn
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-industrial-portfolio
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-industrial-portfolio
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-industrial-portfolio:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-industrial-portfolio
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-industrial-portfolio
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-industrial-portfolio
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uas-lifecycle
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uas-lifecycle
+ image: harbor.cdcyy.com.cn/cmii/cmii-uas-lifecycle:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uas-lifecycle
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uas-lifecycle
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uas-lifecycle
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-data-classification
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-classification
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-classification
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-classification
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-data-classification
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-data-classification:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-data-classification
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-data-classification
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-data-classification
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-classification
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-classification
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-cms
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-cms
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-cms:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-cms
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-cms
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-cms
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-suav-supervision
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-suav-supervision
+ image: harbor.cdcyy.com.cn/cmii/cmii-suav-supervision:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-suav-supervision
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-suav-supervision
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-suav-supervision
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-open-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-open-gateway
+ image: harbor.cdcyy.com.cn/cmii/cmii-open-gateway:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-open-gateway
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-open-gateway
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-open-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-sync
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-sync
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-sync:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-sync
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-sync
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-sync
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-mission
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-mission
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-mission:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-mission
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-mission
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-mission
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-sec-awareness
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sec-awareness
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sec-awareness
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sec-awareness
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-sec-awareness
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-sec-awareness:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-sec-awareness
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-sec-awareness
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-sec-awareness
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sec-awareness
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-sec-awareness
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-mqtthandler
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-mqtthandler
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-mqtthandler:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-mqtthandler
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-mqtthandler
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-mqtthandler
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-grid-datasource
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-grid-datasource
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-grid-datasource:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-grid-datasource
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-grid-datasource
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-grid-datasource
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-device
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-device
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-device:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-device
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-device
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-device
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-admin-user
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-admin-user
+ image: harbor.cdcyy.com.cn/cmii/cmii-admin-user:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-admin-user
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-admin-user
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-admin-user
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-logger
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-logger
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-logger:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-logger
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-logger
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-logger
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-blockchain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-blockchain
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-blockchain:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-blockchain
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-blockchain
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-blockchain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-security-trace
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-security-trace
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-security-trace:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-security-trace
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-security-trace
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-security-trace
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-user
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-user
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-user:6.1.0-yn
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-user
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-user
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-user
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-gis-server
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-gis-server
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-gis-server:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-gis-server
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-gis-server
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-gis-server
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: helm-live-op-v2
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: helm-live-op-v2
+ image: harbor.cdcyy.com.cn/cmii/helm-live-op-v2:5.2.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: helm-live-op-v2
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/helm-live-op-v2
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: helm-live-op-v2
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-brain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-brain
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-brain
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-brain
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-brain
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-brain:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-brain
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-brain
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-brain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-brain
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-brain
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-notice
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-notice
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-notice:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-notice
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-notice
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-notice
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gateway
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gateway
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-gateway
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-gateway:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-gateway
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-gateway
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-gateway
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-autowaypoint
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-autowaypoint
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-autowaypoint:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-autowaypoint
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-autowaypoint
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-autowaypoint
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-oauth
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-oauth
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-oauth:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-oauth
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-oauth
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-oauth
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-grid-engine
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-grid-engine
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-grid-engine:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-grid-engine
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-grid-engine
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-grid-engine
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-cloud-live
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-cloud-live
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-cloud-live:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-cloud-live
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-cloud-live
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-cloud-live
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-surveillance
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-surveillance
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-surveillance
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-surveillance
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-surveillance
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-surveillance:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-surveillance
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-surveillance
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-surveillance
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-surveillance
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-surveillance
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-data-post-process
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-post-process
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-post-process
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-post-process
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-data-post-process
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-data-post-process:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-data-post-process
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-data-post-process
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-data-post-process
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-post-process
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-post-process
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-integration
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-integration
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-integration
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-integration
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-integration
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-integration:5.7.0-szga
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-integration
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-integration
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-integration
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-integration
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-integration
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-iot-dispatcher
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-iot-dispatcher
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-iot-dispatcher
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-iot-dispatcher
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-iot-dispatcher
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-iot-dispatcher:6.1.0-v5
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-iot-dispatcher
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-iot-dispatcher
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-iot-dispatcher
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-iot-dispatcher
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-iot-dispatcher
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-admin-data
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-data
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-admin-data
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-data
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-admin-data
+ image: harbor.cdcyy.com.cn/cmii/cmii-admin-data:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-admin-data
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-admin-data
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-admin-data
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-data
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-admin-data
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uavms-security-center
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uavms-security-center
+ image: harbor.cdcyy.com.cn/cmii/cmii-uavms-security-center:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uavms-security-center
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uavms-security-center
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uavms-security-center
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-airspace
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-airspace
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-airspace:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-airspace
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-airspace
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-airspace
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-process
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-process
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-process:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-process
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-process
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-process
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-app-release
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-app-release
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-app-release
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-app-release
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-app-release
+ image: harbor.cdcyy.com.cn/cmii/cmii-app-release:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-app-release
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-app-release
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-app-release
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-app-release
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-app-release
ports:
- name: backend-tcp
port: 8080
@@ -8060,3 +6531,1393 @@ spec:
port: 8080
protocol: TCP
targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-developer
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-developer
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-developer
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-developer
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-developer
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-developer:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-developer
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-developer
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-developer
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-developer
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-developer
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-kpi-monitor
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-kpi-monitor
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-kpi-monitor:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-kpi-monitor
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-kpi-monitor
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-kpi-monitor
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-container-scanner
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-container-scanner
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-container-scanner:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-container-scanner
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-container-scanner
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-container-scanner
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-clusters
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-clusters
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-clusters:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-clusters
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-clusters
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-clusters
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-multilink
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-multilink
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-multilink
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-multilink
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-multilink
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-multilink:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-multilink
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-multilink
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-multilink
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-multilink
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-multilink
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-alarm
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-alarm
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-alarm
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-alarm
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-alarm
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-alarm:6.2.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-alarm
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-alarm
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-alarm
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-alarm
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-alarm
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-bridge
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-bridge
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-bridge
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-bridge
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-bridge
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-bridge:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-bridge
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-bridge
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-bridge
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-bridge
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-bridge
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: uav-auth-backend
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: uav-auth-backend
+ image: harbor.cdcyy.com.cn/cmii/uav-auth-backend:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: uav-auth-backend
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/uav-auth-backend
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: uav-auth-backend
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-container-scanner-go
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner-go
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner-go
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner-go
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-container-scanner-go
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-container-scanner-go:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-container-scanner-go
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-container-scanner-go
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-container-scanner-go
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner-go
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner-go
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-admin-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-admin-gateway
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-gateway
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-admin-gateway
+ image: harbor.cdcyy.com.cn/cmii/cmii-admin-gateway:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-admin-gateway
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-admin-gateway
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-admin-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-admin-gateway
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
diff --git a/agent-common/real_project/uavcloud-devflight/k8s-configmap.yaml b/agent-common/real_project/uavcloud-devflight/k8s-configmap.yaml
index fd06e35..1b4b568 100644
--- a/agent-common/real_project/uavcloud-devflight/k8s-configmap.yaml
+++ b/agent-common/real_project/uavcloud-devflight/k8s-configmap.yaml
@@ -2,323 +2,15 @@
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-traffic
+ name: tenant-prefix-splice
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "traffic",
- AppClientId: "APP_Jc8i2wOQ1t73QEJS"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-smsecret
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "smsecret",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-armypeople
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "armypeople",
- AppClientId: "APP_UIegse6Lfou9pO1U"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-multiterminal
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "multiterminal",
- AppClientId: "APP_PvdfRRRBPL8xbIwl"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-share
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "share",
- AppClientId: "APP_4lVSVI0ZGxTssir8"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-qingdao
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "qingdao",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-hyper
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "hyper",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-blockchain
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "blockchain",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-secenter
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "secenter",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-cmsportal
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "cmsportal",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-logistics
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "logistics",
- AppClientId: "APP_PvdfRRRBPL8xbIwl"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-qinghaitourism
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "qinghaitourism",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-securityh5
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "securityh5",
- AppClientId: "APP_N3ImO0Ubfu9peRHD"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-threedsimulation
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "threedsimulation",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-uas
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "uas",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-dispatchh5
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "dispatchh5",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-base
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "base",
- AppClientId: "APP_9LY41OaKSqk2btY0"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-media
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "media",
- AppClientId: "APP_4AU8lbifESQO4FD6"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-open
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "open",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-pilot2cloud
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "pilot2cloud",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-awareness
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "awareness",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-pangu
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-oms
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "oms",
- AppClientId: "empty"
+ ApplicationShortName: "splice",
+ AppClientId: "APP_zE0M3sTRXrCIJS8Y"
}
---
kind: ConfigMap
@@ -338,84 +30,14 @@ data:
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-uavmsmanager
+ name: tenant-prefix-hljtt
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "uavmsmanager",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-renyike
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "renyike",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-ai-brain
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "ai-brain",
- AppClientId: "APP_rafnuCAmBESIVYMH"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-splice
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "splice",
- AppClientId: "APP_zE0M3sTRXrCIJS8Y"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-smauth
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "smauth",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-visualization
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "visualization",
+ ApplicationShortName: "hljtt",
AppClientId: "empty"
}
---
@@ -435,90 +57,6 @@ data:
---
kind: ConfigMap
apiVersion: v1
-metadata:
- name: tenant-prefix-classification
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "classification",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-mianyangbackend
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "mianyangbackend",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-dikongzhixingh5
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "dikongzhixingh5",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-supervision
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "supervision",
- AppClientId: "APP_qqSu82THfexI8PLM"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-mws
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "mws",
- AppClientId: "APP_uKniXPELlRERBBwK"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-security
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "security",
- AppClientId: "APP_JUSEMc7afyWXxvE7"
- }
----
-kind: ConfigMap
-apiVersion: v1
metadata:
name: tenant-prefix-scanner
namespace: uavcloud-devflight
@@ -534,14 +72,42 @@ data:
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-eventsh5
+ name: tenant-prefix-secenter
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "eventsh5",
+ ApplicationShortName: "secenter",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-pangu
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-cmsportal
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "cmsportal",
AppClientId: "empty"
}
---
@@ -575,6 +141,174 @@ data:
---
kind: ConfigMap
apiVersion: v1
+metadata:
+ name: tenant-prefix-oms
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "oms",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-open
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "open",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-qinghaitourism
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "qinghaitourism",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-visualization
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "visualization",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-uas
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "uas",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-pilot2cloud
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "pilot2cloud",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-classification
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "classification",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-ai-brain
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "ai-brain",
+ AppClientId: "APP_rafnuCAmBESIVYMH"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-smsecret
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "smsecret",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-mianyangbackend
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "mianyangbackend",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-dikongzhixingh5
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "dikongzhixingh5",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-renyike
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "renyike",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
metadata:
name: tenant-prefix-seniclive
namespace: uavcloud-devflight
@@ -589,6 +323,216 @@ data:
---
kind: ConfigMap
apiVersion: v1
+metadata:
+ name: tenant-prefix-traffic
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "traffic",
+ AppClientId: "APP_Jc8i2wOQ1t73QEJS"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-hyper
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "hyper",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-blockchain
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "blockchain",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-supervision
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "supervision",
+ AppClientId: "APP_qqSu82THfexI8PLM"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-multiterminal
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "multiterminal",
+ AppClientId: "APP_PvdfRRRBPL8xbIwl"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-mws
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "mws",
+ AppClientId: "APP_uKniXPELlRERBBwK"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-dispatchh5
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "dispatchh5",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-logistics
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "logistics",
+ AppClientId: "APP_PvdfRRRBPL8xbIwl"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-threedsimulation
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "threedsimulation",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-qingdao
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "qingdao",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-smauth
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "smauth",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-eventsh5
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "eventsh5",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-flight-control
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "flight-control",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-security
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "security",
+ AppClientId: "APP_JUSEMc7afyWXxvE7"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-securityh5
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "securityh5",
+ AppClientId: "APP_N3ImO0Ubfu9peRHD"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
metadata:
name: tenant-prefix-supervisionh5
namespace: uavcloud-devflight
@@ -604,13 +548,83 @@ data:
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-hljtt
+ name: tenant-prefix-armypeople
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "hljtt",
+ ApplicationShortName: "armypeople",
+ AppClientId: "APP_UIegse6Lfou9pO1U"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-base
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "base",
+ AppClientId: "APP_9LY41OaKSqk2btY0"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-media
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "media",
+ AppClientId: "APP_4AU8lbifESQO4FD6"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-share
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "share",
+ AppClientId: "APP_4lVSVI0ZGxTssir8"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-uavmsmanager
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "uavmsmanager",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-awareness
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "awareness",
AppClientId: "empty"
}
diff --git a/agent-common/real_project/uavcloud-devflight/k8s-frontend.yaml b/agent-common/real_project/uavcloud-devflight/k8s-frontend.yaml
index 41925aa..b409c1b 100644
--- a/agent-common/real_project/uavcloud-devflight/k8s-frontend.yaml
+++ b/agent-common/real_project/uavcloud-devflight/k8s-frontend.yaml
@@ -26,807 +26,6 @@ data:
---
apiVersion: apps/v1
kind: Deployment
-metadata:
- name: cmii-uav-platform-uasms
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-uasms
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-uasms:master-1.1.0-250117
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-uasms
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-uasms
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-uasms
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-threedsimulation
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-threedsimulation
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-threedsimulation
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-threedsimulation
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-threedsimulation
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-threedsimulation:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-threedsimulation
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-threedsimulation
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-threedsimulation
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-threedsimulation
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-threedsimulation
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-open
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-open
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-open:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-open
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-open
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-open
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-armypeople
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-armypeople
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-armypeople:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-armypeople
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-armypeople
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-armypeople
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-media
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-media
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-media:5.7.0-v2
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-media
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-media
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-media
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-pangu
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uavms-platform-security-center
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uavms-platform-security-center
- image: harbor.cdcyy.com.cn/cmii/cmii-uavms-platform-security-center:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uavms-platform-security-center
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-secenter
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uavms-platform-security-center
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-smauth
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-smauth
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-smauth:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-smauth
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-smauth
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-smauth
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-classification
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-classification
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-classification:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-classification
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-classification
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-classification
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
metadata:
name: cmii-uav-platform-detection
namespace: uavcloud-devflight
@@ -916,1252 +115,6 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
-metadata:
- name: cmii-uav-platform-mws
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-mws
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-mws
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-mws
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-mws
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-mws:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-mws
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-mws
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-mws
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-mws
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-mws
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-seniclive
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-seniclive
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-seniclive
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-seniclive
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-seniclive
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-seniclive:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-seniclive
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-seniclive
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-seniclive
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-seniclive
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-seniclive
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-awareness
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-awareness
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-awareness
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-awareness
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-awareness
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-awareness:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-awareness
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-awareness
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-awareness
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-awareness
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-awareness
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-oms
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-oms
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-oms:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-oms
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-oms
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-oms
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-pilot2-to-cloud
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-pilot2-to-cloud
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-pilot2-to-cloud:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-pilot2-to-cloud
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-pilot2cloud
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-pilot2-to-cloud
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-splice
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-splice
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-splice
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-splice
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-splice
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-splice:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-splice
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-splice
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-splice
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-splice
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-splice
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-securityh5
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-securityh5
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-securityh5:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-securityh5
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-securityh5
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-securityh5
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-hljtt
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-hljtt
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-hljtt:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-hljtt
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-hljtt
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-hljtt
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-base
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-base
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-base:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-base
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-base
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-base
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-cms-portal
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-cms-portal
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-cms-portal:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-cms-portal
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-cmsportal
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-cms-portal
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-uas
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-uas
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-uas:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-uas
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-uas
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-uas
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-blockchain
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-blockchain
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-blockchain:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-blockchain
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-blockchain
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-blockchain
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-smsecret
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-smsecret
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-smsecret:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-smsecret
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-smsecret
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-smsecret
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-scanner
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-scanner
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-scanner:5.5.0-integration
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-scanner
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-scanner
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-scanner
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
metadata:
name: cmii-uav-platform-logistics
namespace: uavcloud-devflight
@@ -2251,95 +204,6 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
-metadata:
- name: cmii-uav-platform-share
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-share
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-share
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-share
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-share
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-share:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-share
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-share
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-share
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-share
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-share
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
metadata:
name: cmii-uav-platform-ai-brain
namespace: uavcloud-devflight
@@ -2429,6 +293,95 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
+metadata:
+ name: cmii-uavms-platform-security-center
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uavms-platform-security-center
+ image: harbor.cdcyy.com.cn/cmii/cmii-uavms-platform-security-center:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uavms-platform-security-center
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-secenter
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uavms-platform-security-center
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
metadata:
name: cmii-uavms-platform-manager
namespace: uavcloud-devflight
@@ -2519,11 +472,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-suav-platform-supervision
+ name: cmii-uav-platform-cms-portal
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervision
+ cmii.app: cmii-uav-platform-cms-portal
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -2534,24 +487,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervision
+ cmii.app: cmii-uav-platform-cms-portal
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervision
+ cmii.app: cmii-uav-platform-cms-portal
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-suav-platform-supervision
- image: harbor.cdcyy.com.cn/cmii/cmii-suav-platform-supervision:5.6.0
+ - name: cmii-uav-platform-cms-portal
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-cms-portal:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-suav-platform-supervision
+ value: cmii-uav-platform-cms-portal
ports:
- name: platform-9528
containerPort: 9528
@@ -2579,7 +532,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-supervision
+ name: tenant-prefix-cmsportal
items:
- key: ingress-config.js
path: ingress-config.js
@@ -2587,18 +540,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-suav-platform-supervision
+ name: cmii-uav-platform-cms-portal
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervision
+ cmii.app: cmii-uav-platform-cms-portal
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervision
+ cmii.app: cmii-uav-platform-cms-portal
ports:
- name: web-svc-port
port: 9528
@@ -2608,100 +561,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-jiangsuwenlv
+ name: cmii-uav-platform-oms
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-jiangsuwenlv
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-jiangsuwenlv:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-jiangsuwenlv
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-jiangsuwenlv
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-jiangsuwenlv
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-security
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-security
+ cmii.app: cmii-uav-platform-oms
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -2712,24 +576,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-security
+ cmii.app: cmii-uav-platform-oms
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-security
+ cmii.app: cmii-uav-platform-oms
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-security
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-security:5.6.0
+ - name: cmii-uav-platform-oms
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-oms:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-security
+ value: cmii-uav-platform-oms
ports:
- name: platform-9528
containerPort: 9528
@@ -2757,7 +621,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-security
+ name: tenant-prefix-oms
items:
- key: ingress-config.js
path: ingress-config.js
@@ -2765,18 +629,285 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-security
+ name: cmii-uav-platform-oms
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-security
+ cmii.app: cmii-uav-platform-oms
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-security
+ cmii.app: cmii-uav-platform-oms
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-threedsimulation
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-threedsimulation
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-threedsimulation
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-threedsimulation
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-threedsimulation
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-threedsimulation:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-threedsimulation
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-threedsimulation
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-threedsimulation
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-threedsimulation
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-threedsimulation
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-blockchain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-blockchain
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-blockchain:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-blockchain
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-blockchain
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-blockchain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-armypeople
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-armypeople
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-armypeople
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-armypeople
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-armypeople
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-armypeople:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-armypeople
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-armypeople
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-armypeople
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-armypeople
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-armypeople
ports:
- name: web-svc-port
port: 9528
@@ -2875,39 +1006,39 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-qingdao
+ name: cmii-uav-platform-emergency-rescue
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
+ cmii.app: cmii-uav-platform-emergency-rescue
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
- replicas: 0
+ replicas: 1
strategy:
rollingUpdate:
maxUnavailable: 1
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
+ cmii.app: cmii-uav-platform-emergency-rescue
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
+ cmii.app: cmii-uav-platform-emergency-rescue
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-qingdao
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-qingdao:5.6.0
+ - name: cmii-uav-platform-emergency-rescue
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-emergency-rescue:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-qingdao
+ value: cmii-uav-platform-emergency-rescue
ports:
- name: platform-9528
containerPort: 9528
@@ -2935,7 +1066,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-qingdao
+ name: tenant-prefix-emergency
items:
- key: ingress-config.js
path: ingress-config.js
@@ -2943,18 +1074,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-qingdao
+ name: cmii-uav-platform-emergency-rescue
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
+ cmii.app: cmii-uav-platform-emergency-rescue
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
+ cmii.app: cmii-uav-platform-emergency-rescue
ports:
- name: web-svc-port
port: 9528
@@ -3052,6 +1183,273 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
+metadata:
+ name: cmii-uav-platform-smsecret
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-smsecret
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-smsecret:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-smsecret
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-smsecret
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-smsecret
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-uas
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-uas
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-uas:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-uas
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-uas
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-uas
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-seniclive
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-seniclive
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-seniclive
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-seniclive
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-seniclive
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-seniclive:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-seniclive
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-seniclive
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-seniclive
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-seniclive
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-seniclive
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
metadata:
name: cmii-uav-platform-qinghaitourism
namespace: uavcloud-devflight
@@ -3141,6 +1539,1430 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
+metadata:
+ name: cmii-uav-platform-qingdao
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-qingdao
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-qingdao:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-qingdao
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-qingdao
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-qingdao
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-share
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-share
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-share
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-share
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-share
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-share:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-share
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-share
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-share
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-share
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-share
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-uasms
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uasms
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uasms
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uasms
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-uasms
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-uasms:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-uasms
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-uasms
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-uasms
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uasms
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uasms
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-smauth
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-smauth
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-smauth:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-smauth
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-smauth
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-smauth
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-scanner
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-scanner
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-scanner:5.5.0-integration
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-scanner
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-scanner
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-scanner
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-splice
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-splice
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-splice
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-splice
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-splice
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-splice:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-splice
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-splice
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-splice
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-splice
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-splice
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-hljtt
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hljtt
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hljtt
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hljtt
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-hljtt
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-hljtt:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-hljtt
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-hljtt
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-hljtt
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hljtt
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hljtt
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-security
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-security
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-security:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-security
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-security
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-security
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-jiangsuwenlv
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-jiangsuwenlv
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-jiangsuwenlv
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-jiangsuwenlv
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-jiangsuwenlv
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-jiangsuwenlv:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-jiangsuwenlv
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-jiangsuwenlv
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-jiangsuwenlv
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-jiangsuwenlv
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-jiangsuwenlv
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-classification
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-classification
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-classification:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-classification
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-classification
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-classification
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-hyperspectral
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-hyperspectral
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-hyperspectral:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-hyperspectral
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-hyper
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-hyperspectral
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-base
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-base
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-base
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-base
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-base
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-base:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-base
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-base
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-base
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-base
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-base
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-flight-control
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-flight-control
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-flight-control
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-flight-control
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-flight-control
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-flight-control:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-flight-control
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-flight-control
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-flight-control
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-flight-control
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-flight-control
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-pangu
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-media
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-media
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-media:5.7.0-v2
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-media
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-media
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-media
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-pilot2-to-cloud
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-pilot2-to-cloud
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-pilot2-to-cloud:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-pilot2-to-cloud
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-pilot2cloud
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-pilot2-to-cloud
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
metadata:
name: cmii-uav-platform-visualization
namespace: uavcloud-devflight
@@ -3231,11 +3053,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-emergency-rescue
+ name: cmii-uav-platform-awareness
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
+ cmii.app: cmii-uav-platform-awareness
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -3246,24 +3068,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
+ cmii.app: cmii-uav-platform-awareness
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
+ cmii.app: cmii-uav-platform-awareness
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-emergency-rescue
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-emergency-rescue:5.6.0
+ - name: cmii-uav-platform-awareness
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-awareness:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-emergency-rescue
+ value: cmii-uav-platform-awareness
ports:
- name: platform-9528
containerPort: 9528
@@ -3291,7 +3113,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-emergency
+ name: tenant-prefix-awareness
items:
- key: ingress-config.js
path: ingress-config.js
@@ -3299,18 +3121,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-emergency-rescue
+ name: cmii-uav-platform-awareness
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
+ cmii.app: cmii-uav-platform-awareness
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
+ cmii.app: cmii-uav-platform-awareness
ports:
- name: web-svc-port
port: 9528
@@ -3409,11 +3231,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-hyperspectral
+ name: cmii-uav-platform-open
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-open
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -3424,24 +3246,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-open
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-open
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-hyperspectral
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-hyperspectral:5.7.0-snapshot
+ - name: cmii-uav-platform-open
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-open:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-hyperspectral
+ value: cmii-uav-platform-open
ports:
- name: platform-9528
containerPort: 9528
@@ -3469,7 +3291,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-hyper
+ name: tenant-prefix-open
items:
- key: ingress-config.js
path: ingress-config.js
@@ -3477,18 +3299,285 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-hyperspectral
+ name: cmii-uav-platform-open
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-open
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-open
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-mws
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-mws
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-mws
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-mws
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-mws
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-mws:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-mws
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-mws
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-mws
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-mws
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-mws
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-securityh5
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-securityh5
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-securityh5
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-securityh5
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-securityh5
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-securityh5:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-securityh5
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-securityh5
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-securityh5
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-securityh5
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-securityh5
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-suav-platform-supervision
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervision
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervision
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervision
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-suav-platform-supervision
+ image: harbor.cdcyy.com.cn/cmii/cmii-suav-platform-supervision:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-suav-platform-supervision
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-supervision
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-suav-platform-supervision
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervision
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervision
ports:
- name: web-svc-port
port: 9528
diff --git a/agent-common/real_project/uavcloud-devflight/k8s-ingress.yaml b/agent-common/real_project/uavcloud-devflight/k8s-ingress.yaml
index 0909901..a77cffb 100644
--- a/agent-common/real_project/uavcloud-devflight/k8s-ingress.yaml
+++ b/agent-common/real_project/uavcloud-devflight/k8s-ingress.yaml
@@ -29,6 +29,7 @@ metadata:
rewrite ^(/dispatchh5)$ $1/ redirect;
rewrite ^(/emergency)$ $1/ redirect;
rewrite ^(/eventsh5)$ $1/ redirect;
+ rewrite ^(/flight-control)$ $1/ redirect;
rewrite ^(/hljtt)$ $1/ redirect;
rewrite ^(/hyper)$ $1/ redirect;
rewrite ^(/jiangsuwenlv)$ $1/ redirect;
@@ -143,6 +144,11 @@ spec:
backend:
serviceName: cmii-uav-platform-eventsh5
servicePort: 9528
+ - path: /devflight/flight-control/?(.*)
+ pathType: ImplementationSpecific
+ backend:
+ serviceName: cmii-uav-platform-flight-control
+ servicePort: 9528
- path: /devflight/hljtt/?(.*)
pathType: ImplementationSpecific
backend:
diff --git a/agent-common/real_project/uavcloud-devflight/old/k8s-backend.yaml b/agent-common/real_project/uavcloud-devflight/old/k8s-backend.yaml
index 26c093a..2532b83 100644
--- a/agent-common/real_project/uavcloud-devflight/old/k8s-backend.yaml
+++ b/agent-common/real_project/uavcloud-devflight/old/k8s-backend.yaml
@@ -2,11 +2,150 @@
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-airspace
+ name: cmii-uav-grid-datasource
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-airspace
+ cmii.app: cmii-uav-grid-datasource
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-grid-datasource
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-grid-datasource:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-grid-datasource
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-grid-datasource
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-grid-datasource
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-datasource
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-surveillance
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-surveillance
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -18,12 +157,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-airspace
+ cmii.app: cmii-uav-surveillance
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-airspace
+ cmii.app: cmii-uav-surveillance
spec:
affinity:
nodeAffinity:
@@ -37,14 +176,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-airspace
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-airspace:6.0.0
+ - name: cmii-uav-surveillance
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-surveillance:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-airspace
+ value: cmii-uav-surveillance
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -110,7 +249,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-airspace
+ subPath: uavcloud-devflight/cmii-uav-surveillance
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -119,11 +258,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-airspace
+ name: cmii-uav-surveillance
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-airspace
+ cmii.app: cmii-uav-surveillance
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -131,563 +270,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-airspace
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uas-lifecycle
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uas-lifecycle
- image: harbor.cdcyy.com.cn/cmii/cmii-uas-lifecycle:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uas-lifecycle
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uas-lifecycle
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uas-lifecycle
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uas-lifecycle
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-autowaypoint
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-autowaypoint
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-autowaypoint:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-autowaypoint
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-autowaypoint
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-autowaypoint
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-autowaypoint
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-waypoint
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-waypoint
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-waypoint:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-waypoint
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-waypoint
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-waypoint
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-waypoint
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-grid-engine
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-grid-engine
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-grid-engine:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-grid-engine
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-grid-engine
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-grid-engine
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-grid-engine
+ cmii.app: cmii-uav-surveillance
ports:
- name: backend-tcp
port: 8080
@@ -836,11 +419,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-kpi-monitor
+ name: cmii-uav-multilink
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
+ cmii.app: cmii-uav-multilink
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -852,12 +435,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
+ cmii.app: cmii-uav-multilink
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
+ cmii.app: cmii-uav-multilink
spec:
affinity:
nodeAffinity:
@@ -871,14 +454,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-kpi-monitor
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-kpi-monitor:6.0.0
+ - name: cmii-uav-multilink
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-multilink:6.0.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-kpi-monitor
+ value: cmii-uav-multilink
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -944,7 +527,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-kpi-monitor
+ subPath: uavcloud-devflight/cmii-uav-multilink
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -953,11 +536,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-kpi-monitor
+ name: cmii-uav-multilink
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
+ cmii.app: cmii-uav-multilink
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -965,7 +548,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-kpi-monitor
+ cmii.app: cmii-uav-multilink
ports:
- name: backend-tcp
port: 8080
@@ -975,11 +558,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-data-classification
+ name: cmii-uav-advanced5g
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-advanced5g
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -991,12 +574,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-advanced5g
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-advanced5g
spec:
affinity:
nodeAffinity:
@@ -1010,14 +593,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-data-classification
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-data-classification:5.7.0-snapshot
+ - name: cmii-uav-advanced5g
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-advanced5g:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-data-classification
+ value: cmii-uav-advanced5g
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -1083,7 +666,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-data-classification
+ subPath: uavcloud-devflight/cmii-uav-advanced5g
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -1092,11 +675,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-data-classification
+ name: cmii-uav-advanced5g
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-advanced5g
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -1104,7 +687,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-data-classification
+ cmii.app: cmii-uav-advanced5g
ports:
- name: backend-tcp
port: 8080
@@ -1114,11 +697,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-threedsimulation
+ name: cmii-uav-iot-dispatcher
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-threedsimulation
+ cmii.app: cmii-uav-iot-dispatcher
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -1130,12 +713,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-threedsimulation
+ cmii.app: cmii-uav-iot-dispatcher
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-threedsimulation
+ cmii.app: cmii-uav-iot-dispatcher
spec:
affinity:
nodeAffinity:
@@ -1149,14 +732,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-threedsimulation
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-threedsimulation:6.0.0
+ - name: cmii-uav-iot-dispatcher
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-iot-dispatcher:6.1.0-v5
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-threedsimulation
+ value: cmii-uav-iot-dispatcher
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -1222,7 +805,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-threedsimulation
+ subPath: uavcloud-devflight/cmii-uav-iot-dispatcher
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -1231,11 +814,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-threedsimulation
+ name: cmii-uav-iot-dispatcher
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-threedsimulation
+ cmii.app: cmii-uav-iot-dispatcher
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -1243,7 +826,285 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-threedsimulation
+ cmii.app: cmii-uav-iot-dispatcher
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-grid-engine
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-grid-engine
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-grid-engine:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-grid-engine
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-grid-engine
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-grid-engine
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-grid-engine
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uas-lifecycle
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uas-lifecycle
+ image: harbor.cdcyy.com.cn/cmii/cmii-uas-lifecycle:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uas-lifecycle
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uas-lifecycle
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uas-lifecycle
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uas-lifecycle
ports:
- name: backend-tcp
port: 8080
@@ -1392,150 +1253,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-sky-converge
+ name: cmii-uav-data-post-process
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-sky-converge
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-sky-converge
- image: harbor.cdcyy.com.cn/cmii/cmii-sky-converge:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-sky-converge
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-sky-converge
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-sky-converge
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-sky-converge
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-fwdd
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-fwdd
+ cmii.app: cmii-uav-data-post-process
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -1547,12 +1269,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-fwdd
+ cmii.app: cmii-uav-data-post-process
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-fwdd
+ cmii.app: cmii-uav-data-post-process
spec:
affinity:
nodeAffinity:
@@ -1566,14 +1288,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-fwdd
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-fwdd:6.0.0
+ - name: cmii-uav-data-post-process
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-data-post-process:6.0.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-fwdd
+ value: cmii-uav-data-post-process
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -1639,7 +1361,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-fwdd
+ subPath: uavcloud-devflight/cmii-uav-data-post-process
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -1648,11 +1370,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-fwdd
+ name: cmii-uav-data-post-process
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-fwdd
+ cmii.app: cmii-uav-data-post-process
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -1660,7 +1382,1675 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-fwdd
+ cmii.app: cmii-uav-data-post-process
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: helm-live-op-v2
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: helm-live-op-v2
+ image: harbor.cdcyy.com.cn/cmii/helm-live-op-v2:5.2.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: helm-live-op-v2
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/helm-live-op-v2
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: helm-live-op-v2
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: helm-live-op-v2
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-threedsimulation
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-threedsimulation
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-threedsimulation
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-threedsimulation
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-threedsimulation
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-threedsimulation:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-threedsimulation
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-threedsimulation
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-threedsimulation
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-threedsimulation
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-threedsimulation
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-mission
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-mission
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-mission:5.7.0-szga
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-mission
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-mission
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-mission
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-mission
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-device
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-device
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-device:5.7.0-szga
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-device
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-device
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-device
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-device
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-process
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-process
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-process:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-process
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-process
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-process
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-process
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-clusters
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-clusters
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-clusters:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-clusters
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-clusters
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-clusters
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-clusters
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-sync
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-sync
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-sync:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-sync
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-sync
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-sync
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-sync
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-oauth
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-oauth
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-oauth:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-oauth
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-oauth
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-oauth
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-oauth
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-airspace
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-airspace
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-airspace:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-airspace
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-airspace
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-airspace
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-airspace
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-autowaypoint
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-autowaypoint
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-autowaypoint:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-autowaypoint
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-autowaypoint
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-autowaypoint
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-autowaypoint
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-cms
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-cms
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-cms:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-cms
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-cms
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-cms
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-cms
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-kpi-monitor
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-kpi-monitor
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-kpi-monitor:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-kpi-monitor
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-kpi-monitor
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-kpi-monitor
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-kpi-monitor
ports:
- name: backend-tcp
port: 8080
@@ -1809,11 +3199,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-sec-awareness
+ name: cmii-uav-container-scanner-go
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
+ cmii.app: cmii-uav-container-scanner-go
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -1825,12 +3215,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
+ cmii.app: cmii-uav-container-scanner-go
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
+ cmii.app: cmii-uav-container-scanner-go
spec:
affinity:
nodeAffinity:
@@ -1844,14 +3234,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-sec-awareness
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-sec-awareness:6.0.0
+ - name: cmii-uav-container-scanner-go
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-container-scanner-go:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-sec-awareness
+ value: cmii-uav-container-scanner-go
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -1917,7 +3307,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-sec-awareness
+ subPath: uavcloud-devflight/cmii-uav-container-scanner-go
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -1926,11 +3316,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-sec-awareness
+ name: cmii-uav-container-scanner-go
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
+ cmii.app: cmii-uav-container-scanner-go
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -1938,7 +3328,2648 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-sec-awareness
+ cmii.app: cmii-uav-container-scanner-go
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-blockchain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-blockchain
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-blockchain:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-blockchain
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-blockchain
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-blockchain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-blockchain
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-mqtthandler
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-mqtthandler
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-mqtthandler:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-mqtthandler
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-mqtthandler
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-mqtthandler
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-mqtthandler
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-user
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-user
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-user:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-user
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-user
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-user
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-user
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-logger
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-logger
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-logger:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-logger
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-logger
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-logger
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-logger
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-cloud-live
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-cloud-live
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-cloud-live:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-cloud-live
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-cloud-live
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-cloud-live
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-cloud-live
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-waypoint
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-waypoint
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-waypoint:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-waypoint
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-waypoint
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-waypoint
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-waypoint
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: uav-auth-backend
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: uav-auth-backend
+ image: harbor.cdcyy.com.cn/cmii/uav-auth-backend:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: uav-auth-backend
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/uav-auth-backend
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: uav-auth-backend
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: uav-auth-backend
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-depotautoreturn
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-depotautoreturn
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-depotautoreturn:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-depotautoreturn
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-depotautoreturn
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-depotautoreturn
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-depotautoreturn
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uas-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uas-gateway
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-gateway
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uas-gateway
+ image: harbor.cdcyy.com.cn/cmii/cmii-uas-gateway:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uas-gateway
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uas-gateway
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uas-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uas-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uas-gateway
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-admin-user
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-admin-user
+ image: harbor.cdcyy.com.cn/cmii/cmii-admin-user:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-admin-user
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-admin-user
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-admin-user
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-admin-user
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-sky-converge
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-sky-converge
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-sky-converge
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-sky-converge
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-sky-converge
+ image: harbor.cdcyy.com.cn/cmii/cmii-sky-converge:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-sky-converge
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-sky-converge
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-sky-converge
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-sky-converge
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-sky-converge
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-suav-supervision
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-suav-supervision
+ image: harbor.cdcyy.com.cn/cmii/cmii-suav-supervision:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-suav-supervision
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-suav-supervision
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-suav-supervision
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-suav-supervision
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uavms-security-center
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uavms-security-center
+ image: harbor.cdcyy.com.cn/cmii/cmii-uavms-security-center:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uavms-security-center
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uavms-security-center
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uavms-security-center
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uavms-security-center
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-container-scanner
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-container-scanner
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-container-scanner:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-container-scanner
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-container-scanner
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-container-scanner
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-container-scanner
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-notice
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-notice
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-notice:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-notice
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-notice
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-notice
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-notice
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-tower
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-tower
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-tower
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-tower
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-tower
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-tower:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-tower
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-tower
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-tower
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-tower
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-tower
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-gis-server
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-gis-server
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-gis-server:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-gis-server
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-gis-server
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-gis-server
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-gis-server
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-sense-adapter
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-sense-adapter
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-sense-adapter:6.2.0-25021802
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-sense-adapter
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-sense-adapter
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-sense-adapter
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-sense-adapter
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-open-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-open-gateway
+ image: harbor.cdcyy.com.cn/cmii/cmii-open-gateway:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-open-gateway
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-open-gateway
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-open-gateway
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-open-gateway
ports:
- name: backend-tcp
port: 8080
@@ -1984,7 +6015,7 @@ spec:
- name: harborsecret
containers:
- name: cmii-uav-integration
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-integration:6.0.0
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-integration:5.7.0-szga
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
@@ -2226,11 +6257,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-container-scanner
+ name: uav-secret-backend
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-container-scanner
+ cmii.app: uav-secret-backend
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -2242,12 +6273,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-container-scanner
+ cmii.app: uav-secret-backend
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-container-scanner
+ cmii.app: uav-secret-backend
spec:
affinity:
nodeAffinity:
@@ -2261,14 +6292,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-container-scanner
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-container-scanner:5.7.0-snapshot
+ - name: uav-secret-backend
+ image: harbor.cdcyy.com.cn/cmii/uav-secret-backend:6.0.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-container-scanner
+ value: uav-secret-backend
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -2334,7 +6365,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-container-scanner
+ subPath: uavcloud-devflight/uav-secret-backend
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -2343,11 +6374,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-container-scanner
+ name: uav-secret-backend
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-container-scanner
+ cmii.app: uav-secret-backend
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -2355,2926 +6386,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-container-scanner
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-open-gateway
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-open-gateway
- image: harbor.cdcyy.com.cn/cmii/cmii-open-gateway:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-open-gateway
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-open-gateway
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-open-gateway
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-open-gateway
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-mission
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-mission
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-mission:5.7.0-hebei
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-mission
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-mission
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-mission
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-mission
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uas-gateway
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-gateway
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uas-gateway
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-gateway
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uas-gateway
- image: harbor.cdcyy.com.cn/cmii/cmii-uas-gateway:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uas-gateway
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uas-gateway
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uas-gateway
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uas-gateway
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uas-gateway
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-developer
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-developer
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-developer:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-developer
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-developer
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-developer
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-developer
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-container-scanner-go
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-container-scanner-go
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-container-scanner-go:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-container-scanner-go
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-container-scanner-go
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-container-scanner-go
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-container-scanner-go
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-notice
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-notice
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-notice:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-notice
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-notice
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-notice
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-notice
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-app-release
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-app-release
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-app-release
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-app-release
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-app-release
- image: harbor.cdcyy.com.cn/cmii/cmii-app-release:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-app-release
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-app-release
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-app-release
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-app-release
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-app-release
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-surveillance
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-surveillance
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-surveillance:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-surveillance
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-surveillance
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-surveillance
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-surveillance
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-security-trace
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-security-trace
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-security-trace:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-security-trace
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-security-trace
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-security-trace
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-security-trace
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-clusters
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-clusters
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-clusters:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-clusters
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-clusters
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-clusters
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-clusters
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-process
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-process
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-process
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-process
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-process
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-process:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-process
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-process
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-process
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-process
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-process
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-tower
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-tower
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-tower:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-tower
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-tower
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-tower
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-tower
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-sync
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-sync
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-sync:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-sync
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-sync
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-sync
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-sync
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-depotautoreturn
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-depotautoreturn
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-depotautoreturn:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-depotautoreturn
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-depotautoreturn
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-depotautoreturn
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-depotautoreturn
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: helm-live-op-v2
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: helm-live-op-v2
- image: harbor.cdcyy.com.cn/cmii/helm-live-op-v2:5.2.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: helm-live-op-v2
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/helm-live-op-v2
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: helm-live-op-v2
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: helm-live-op-v2
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-data-post-process
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-data-post-process
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-data-post-process:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-data-post-process
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-data-post-process
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-data-post-process
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-data-post-process
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-iot-dispatcher
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-iot-dispatcher
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-iot-dispatcher:6.1.0-v5
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-iot-dispatcher
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-iot-dispatcher
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-iot-dispatcher
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-iot-dispatcher
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-suav-supervision
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-suav-supervision
- image: harbor.cdcyy.com.cn/cmii/cmii-suav-supervision:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-suav-supervision
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-suav-supervision
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-suav-supervision
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-suav-supervision
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-device
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-device
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-device
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-device
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-device
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-device:5.7.0-szga
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-device
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-device
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-device
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-device
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-device
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-advanced5g
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-advanced5g
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-advanced5g:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-advanced5g
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-advanced5g
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-advanced5g
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-advanced5g
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-multilink
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-multilink
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-multilink:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-multilink
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-multilink
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-multilink
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-multilink
+ cmii.app: uav-secret-backend
ports:
- name: backend-tcp
port: 8080
@@ -5422,979 +6534,6 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
-metadata:
- name: cmii-uav-industrial-portfolio
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-industrial-portfolio
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-industrial-portfolio:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-industrial-portfolio
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-industrial-portfolio
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-industrial-portfolio
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-industrial-portfolio
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-material-warehouse
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-material-warehouse
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-material-warehouse
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-material-warehouse
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-material-warehouse
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-material-warehouse:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-material-warehouse
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-material-warehouse
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-material-warehouse
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-material-warehouse
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-material-warehouse
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-logger
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-logger
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-logger:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-logger
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-logger
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-logger
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-logger
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-user
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-user
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-user
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-user
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-user
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-user:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-user
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-user
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-user
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-user
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-user
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-cloud-live
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-cloud-live
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-cloud-live:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-cloud-live
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-cloud-live
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-cloud-live
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-cloud-live
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-oauth
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-oauth
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-oauth:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-oauth
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-oauth
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-oauth
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-oauth
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uavms-security-center
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uavms-security-center
- image: harbor.cdcyy.com.cn/cmii/cmii-uavms-security-center:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uavms-security-center
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uavms-security-center
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uavms-security-center
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uavms-security-center
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
metadata:
name: cmii-uav-bridge
namespace: uavcloud-devflight
@@ -6535,11 +6674,289 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-gis-server
+ name: cmii-uav-industrial-portfolio
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-gis-server
+ cmii.app: cmii-uav-industrial-portfolio
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-industrial-portfolio
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-industrial-portfolio:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-industrial-portfolio
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-industrial-portfolio
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-industrial-portfolio
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-industrial-portfolio
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-security-trace
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-security-trace
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-security-trace:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-security-trace
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-uav-security-trace
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-security-trace
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-uav-security-trace
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-developer
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-developer
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -6551,12 +6968,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-gis-server
+ cmii.app: cmii-uav-developer
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-gis-server
+ cmii.app: cmii-uav-developer
spec:
affinity:
nodeAffinity:
@@ -6570,14 +6987,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-gis-server
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-gis-server:6.0.0
+ - name: cmii-uav-developer
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-developer:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-gis-server
+ value: cmii-uav-developer
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -6643,7 +7060,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-gis-server
+ subPath: uavcloud-devflight/cmii-uav-developer
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -6652,11 +7069,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-gis-server
+ name: cmii-uav-developer
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-gis-server
+ cmii.app: cmii-uav-developer
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -6664,7 +7081,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-gis-server
+ cmii.app: cmii-uav-developer
ports:
- name: backend-tcp
port: 8080
@@ -6674,11 +7091,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-admin-gateway
+ name: cmii-uav-sec-awareness
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-uav-sec-awareness
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -6690,12 +7107,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-uav-sec-awareness
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-uav-sec-awareness
spec:
affinity:
nodeAffinity:
@@ -6709,14 +7126,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-admin-gateway
- image: harbor.cdcyy.com.cn/cmii/cmii-admin-gateway:6.0.0
+ - name: cmii-uav-sec-awareness
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-sec-awareness:6.0.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-admin-gateway
+ value: cmii-uav-sec-awareness
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -6782,7 +7199,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-admin-gateway
+ subPath: uavcloud-devflight/cmii-uav-sec-awareness
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -6791,11 +7208,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-admin-gateway
+ name: cmii-uav-sec-awareness
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-uav-sec-awareness
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -6803,7 +7220,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-admin-gateway
+ cmii.app: cmii-uav-sec-awareness
ports:
- name: backend-tcp
port: 8080
@@ -6813,11 +7230,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-grid-datasource
+ name: cmii-uav-fwdd
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-fwdd
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -6829,12 +7246,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-fwdd
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-fwdd
spec:
affinity:
nodeAffinity:
@@ -6848,14 +7265,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-grid-datasource
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-grid-datasource:6.0.0
+ - name: cmii-uav-fwdd
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-fwdd:6.0.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-grid-datasource
+ value: cmii-uav-fwdd
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -6921,7 +7338,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-grid-datasource
+ subPath: uavcloud-devflight/cmii-uav-fwdd
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -6930,11 +7347,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-grid-datasource
+ name: cmii-uav-fwdd
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-fwdd
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -6942,7 +7359,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-grid-datasource
+ cmii.app: cmii-uav-fwdd
ports:
- name: backend-tcp
port: 8080
@@ -6952,11 +7369,150 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-cms
+ name: cmii-app-release
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-cms
+ cmii.app: cmii-app-release
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: backend
+ cmii.app: cmii-app-release
+ template:
+ metadata:
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-app-release
+ spec:
+ affinity:
+ nodeAffinity:
+ requiredDuringSchedulingIgnoredDuringExecution:
+ nodeSelectorTerms:
+ - matchExpressions:
+ - key: uavcloud.env
+ operator: In
+ values:
+ - devflight
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-app-release
+ image: harbor.cdcyy.com.cn/cmii/cmii-app-release:6.0.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-app-release
+ - name: CUST_JAVA_OPTS
+ value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
+ - name: NACOS_REGISTRY
+ value: "helm-nacos:8848"
+ - name: NACOS_DISCOVERY_IP
+ valueFrom:
+ fieldRef:
+ fieldPath: status.podIP
+ - name: NACOS_DISCOVERY_PORT
+ value: "8080"
+ - name: BIZ_CONFIG_GROUP
+ value: 6.0.0
+ - name: SYS_CONFIG_GROUP
+ value: 6.0.0
+ - name: IMAGE_VERSION
+ value: 6.0.0
+ - name: NACOS_USERNAME
+ value: "developer"
+ - name: NACOS_PASSWORD
+ value: "Deve@9128201"
+ ports:
+ - name: pod-port
+ containerPort: 8080
+ protocol: TCP
+ resources:
+ limits:
+ memory: 2Gi
+ cpu: "2"
+ requests:
+ memory: 200Mi
+ cpu: 200m
+ livenessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ readinessProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 5
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 3
+ startupProbe:
+ httpGet:
+ path: /cmii/health
+ port: pod-port
+ scheme: HTTP
+ initialDelaySeconds: 60
+ timeoutSeconds: 3
+ periodSeconds: 20
+ successThreshold: 1
+ failureThreshold: 5
+ volumeMounts:
+ - name: nfs-backend-log-volume
+ mountPath: /cmii/logs
+ readOnly: false
+ subPath: uavcloud-devflight/cmii-app-release
+ volumes:
+ - name: nfs-backend-log-volume
+ persistentVolumeClaim:
+ claimName: nfs-backend-log-pvc
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-app-release
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-app-release
+ octopus/control: backend-app-1.0.0
+ app.kubernetes.io/managed-by: octopus
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: backend
+ cmii.app: cmii-app-release
+ ports:
+ - name: backend-tcp
+ port: 8080
+ protocol: TCP
+ targetPort: 8080
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-data-classification
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: backend
+ cmii.app: cmii-uav-data-classification
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -6968,12 +7524,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-cms
+ cmii.app: cmii-uav-data-classification
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-cms
+ cmii.app: cmii-uav-data-classification
spec:
affinity:
nodeAffinity:
@@ -6987,14 +7543,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-cms
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-cms:6.0.0
+ - name: cmii-uav-data-classification
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-data-classification:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-cms
+ value: cmii-uav-data-classification
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -7060,7 +7616,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-cms
+ subPath: uavcloud-devflight/cmii-uav-data-classification
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -7069,11 +7625,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-cms
+ name: cmii-uav-data-classification
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-cms
+ cmii.app: cmii-uav-data-classification
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7081,285 +7637,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-cms
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-sense-adapter
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-sense-adapter
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-sense-adapter:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-sense-adapter
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-uav-sense-adapter
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-sense-adapter
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-uav-sense-adapter
- ports:
- - name: backend-tcp
- port: 8080
- protocol: TCP
- targetPort: 8080
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-admin-user
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-user
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: backend
- cmii.app: cmii-admin-user
- template:
- metadata:
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-user
- spec:
- affinity:
- nodeAffinity:
- requiredDuringSchedulingIgnoredDuringExecution:
- nodeSelectorTerms:
- - matchExpressions:
- - key: uavcloud.env
- operator: In
- values:
- - devflight
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-admin-user
- image: harbor.cdcyy.com.cn/cmii/cmii-admin-user:6.0.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-admin-user
- - name: CUST_JAVA_OPTS
- value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- - name: NACOS_REGISTRY
- value: "helm-nacos:8848"
- - name: NACOS_DISCOVERY_IP
- valueFrom:
- fieldRef:
- fieldPath: status.podIP
- - name: NACOS_DISCOVERY_PORT
- value: "8080"
- - name: BIZ_CONFIG_GROUP
- value: 6.0.0
- - name: SYS_CONFIG_GROUP
- value: 6.0.0
- - name: IMAGE_VERSION
- value: 6.0.0
- - name: NACOS_USERNAME
- value: "developer"
- - name: NACOS_PASSWORD
- value: "Deve@9128201"
- ports:
- - name: pod-port
- containerPort: 8080
- protocol: TCP
- resources:
- limits:
- memory: 2Gi
- cpu: "2"
- requests:
- memory: 200Mi
- cpu: 200m
- livenessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- readinessProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 5
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 3
- startupProbe:
- httpGet:
- path: /cmii/health
- port: pod-port
- scheme: HTTP
- initialDelaySeconds: 60
- timeoutSeconds: 3
- periodSeconds: 20
- successThreshold: 1
- failureThreshold: 5
- volumeMounts:
- - name: nfs-backend-log-volume
- mountPath: /cmii/logs
- readOnly: false
- subPath: uavcloud-devflight/cmii-admin-user
- volumes:
- - name: nfs-backend-log-volume
- persistentVolumeClaim:
- claimName: nfs-backend-log-pvc
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-admin-user
- namespace: uavcloud-devflight
- labels:
- cmii.type: backend
- cmii.app: cmii-admin-user
- octopus/control: backend-app-1.0.0
- app.kubernetes.io/managed-by: octopus
- app.kubernetes.io/app-version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: backend
- cmii.app: cmii-admin-user
+ cmii.app: cmii-uav-data-classification
ports:
- name: backend-tcp
port: 8080
@@ -7508,11 +7786,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-mqtthandler
+ name: cmii-admin-gateway
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
+ cmii.app: cmii-admin-gateway
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7524,12 +7802,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
+ cmii.app: cmii-admin-gateway
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
+ cmii.app: cmii-admin-gateway
spec:
affinity:
nodeAffinity:
@@ -7543,14 +7821,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-mqtthandler
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-mqtthandler:5.7.0-snapshot
+ - name: cmii-admin-gateway
+ image: harbor.cdcyy.com.cn/cmii/cmii-admin-gateway:6.0.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-mqtthandler
+ value: cmii-admin-gateway
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -7616,7 +7894,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-mqtthandler
+ subPath: uavcloud-devflight/cmii-admin-gateway
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -7625,11 +7903,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-mqtthandler
+ name: cmii-admin-gateway
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
+ cmii.app: cmii-admin-gateway
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7637,7 +7915,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-mqtthandler
+ cmii.app: cmii-admin-gateway
ports:
- name: backend-tcp
port: 8080
@@ -7647,11 +7925,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-blockchain
+ name: cmii-uav-material-warehouse
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-blockchain
+ cmii.app: cmii-uav-material-warehouse
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7663,12 +7941,12 @@ spec:
selector:
matchLabels:
cmii.type: backend
- cmii.app: cmii-uav-blockchain
+ cmii.app: cmii-uav-material-warehouse
template:
metadata:
labels:
cmii.type: backend
- cmii.app: cmii-uav-blockchain
+ cmii.app: cmii-uav-material-warehouse
spec:
affinity:
nodeAffinity:
@@ -7682,14 +7960,14 @@ spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-blockchain
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-blockchain:6.0.0-snapshot
+ - name: cmii-uav-material-warehouse
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-material-warehouse:6.0.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-blockchain
+ value: cmii-uav-material-warehouse
- name: CUST_JAVA_OPTS
value: "-Xms200m -Xmx1500m -Dlog4j2.formatMsgNoLookups=true"
- name: NACOS_REGISTRY
@@ -7755,7 +8033,7 @@ spec:
- name: nfs-backend-log-volume
mountPath: /cmii/logs
readOnly: false
- subPath: uavcloud-devflight/cmii-uav-blockchain
+ subPath: uavcloud-devflight/cmii-uav-material-warehouse
volumes:
- name: nfs-backend-log-volume
persistentVolumeClaim:
@@ -7764,11 +8042,11 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-blockchain
+ name: cmii-uav-material-warehouse
namespace: uavcloud-devflight
labels:
cmii.type: backend
- cmii.app: cmii-uav-blockchain
+ cmii.app: cmii-uav-material-warehouse
octopus/control: backend-app-1.0.0
app.kubernetes.io/managed-by: octopus
app.kubernetes.io/app-version: 6.0.0
@@ -7776,7 +8054,7 @@ spec:
type: ClusterIP
selector:
cmii.type: backend
- cmii.app: cmii-uav-blockchain
+ cmii.app: cmii-uav-material-warehouse
ports:
- name: backend-tcp
port: 8080
diff --git a/agent-common/real_project/uavcloud-devflight/old/k8s-configmap.yaml b/agent-common/real_project/uavcloud-devflight/old/k8s-configmap.yaml
index 0c700fd..fd06e35 100644
--- a/agent-common/real_project/uavcloud-devflight/old/k8s-configmap.yaml
+++ b/agent-common/real_project/uavcloud-devflight/old/k8s-configmap.yaml
@@ -2,43 +2,71 @@
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-seniclive
+ name: tenant-prefix-traffic
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "seniclive",
+ ApplicationShortName: "traffic",
+ AppClientId: "APP_Jc8i2wOQ1t73QEJS"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-smsecret
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "smsecret",
AppClientId: "empty"
}
---
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-splice
+ name: tenant-prefix-armypeople
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "splice",
- AppClientId: "APP_zE0M3sTRXrCIJS8Y"
+ ApplicationShortName: "armypeople",
+ AppClientId: "APP_UIegse6Lfou9pO1U"
}
---
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-security
+ name: tenant-prefix-multiterminal
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "security",
- AppClientId: "APP_JUSEMc7afyWXxvE7"
+ ApplicationShortName: "multiterminal",
+ AppClientId: "APP_PvdfRRRBPL8xbIwl"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-share
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "share",
+ AppClientId: "APP_4lVSVI0ZGxTssir8"
}
---
kind: ConfigMap
@@ -57,6 +85,20 @@ data:
---
kind: ConfigMap
apiVersion: v1
+metadata:
+ name: tenant-prefix-hyper
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "hyper",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
metadata:
name: tenant-prefix-blockchain
namespace: uavcloud-devflight
@@ -71,272 +113,6 @@ data:
---
kind: ConfigMap
apiVersion: v1
-metadata:
- name: tenant-prefix-supervision
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "supervision",
- AppClientId: "APP_qqSu82THfexI8PLM"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-ai-brain
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "ai-brain",
- AppClientId: "APP_rafnuCAmBESIVYMH"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-logistics
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "logistics",
- AppClientId: "APP_PvdfRRRBPL8xbIwl"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-mws
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "mws",
- AppClientId: "APP_uKniXPELlRERBBwK"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-oms
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "oms",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-eventsh5
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "eventsh5",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-mianyangbackend
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "mianyangbackend",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-dikongzhixingh5
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "dikongzhixingh5",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-renyike
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "renyike",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-base
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "base",
- AppClientId: "APP_9LY41OaKSqk2btY0"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-emergency
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "emergency",
- AppClientId: "APP_aGsTAY1uMZrpKdfk"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-open
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "open",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-pilot2cloud
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "pilot2cloud",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-scanner
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "scanner",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-pangu
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-media
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "media",
- AppClientId: "APP_4AU8lbifESQO4FD6"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-jiangsuwenlv
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "jiangsuwenlv",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-uasms
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "uasms",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-uavmsmanager
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "uavmsmanager",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
metadata:
name: tenant-prefix-secenter
namespace: uavcloud-devflight
@@ -366,28 +142,14 @@ data:
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-detection
+ name: tenant-prefix-logistics
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "detection",
- AppClientId: "APP_FDHW2VLVDWPnnOCy"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-multiterminal
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "multiterminal",
+ ApplicationShortName: "logistics",
AppClientId: "APP_PvdfRRRBPL8xbIwl"
}
---
@@ -407,90 +169,6 @@ data:
---
kind: ConfigMap
apiVersion: v1
-metadata:
- name: tenant-prefix-hljtt
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "hljtt",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-uas
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "uas",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-smsecret
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "smsecret",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-classification
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "classification",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-smauth
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "smauth",
- AppClientId: "empty"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-supervisionh5
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "supervisionh5",
- AppClientId: "APP_qqSu82THfexI8PLM"
- }
----
-kind: ConfigMap
-apiVersion: v1
metadata:
name: tenant-prefix-securityh5
namespace: uavcloud-devflight
@@ -520,14 +198,14 @@ data:
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-visualization
+ name: tenant-prefix-uas
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "visualization",
+ ApplicationShortName: "uas",
AppClientId: "empty"
}
---
@@ -548,55 +226,391 @@ data:
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-armypeople
+ name: tenant-prefix-base
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "armypeople",
- AppClientId: "APP_UIegse6Lfou9pO1U"
+ ApplicationShortName: "base",
+ AppClientId: "APP_9LY41OaKSqk2btY0"
}
---
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-share
+ name: tenant-prefix-media
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "share",
- AppClientId: "APP_4lVSVI0ZGxTssir8"
+ ApplicationShortName: "media",
+ AppClientId: "APP_4AU8lbifESQO4FD6"
}
---
kind: ConfigMap
apiVersion: v1
metadata:
- name: tenant-prefix-traffic
+ name: tenant-prefix-open
namespace: uavcloud-devflight
data:
ingress-config.js: |-
var __GlobalIngressConfig = {
TenantEnvironment: "devflight",
CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "traffic",
- AppClientId: "APP_Jc8i2wOQ1t73QEJS"
- }
----
-kind: ConfigMap
-apiVersion: v1
-metadata:
- name: tenant-prefix-hyper
- namespace: uavcloud-devflight
-data:
- ingress-config.js: |-
- var __GlobalIngressConfig = {
- TenantEnvironment: "devflight",
- CloudHOST: "lab.uavcmlc.com",
- ApplicationShortName: "hyper",
+ ApplicationShortName: "open",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-pilot2cloud
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "pilot2cloud",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-awareness
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "awareness",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-pangu
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-oms
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "oms",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-jiangsuwenlv
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "jiangsuwenlv",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-uavmsmanager
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "uavmsmanager",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-renyike
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "renyike",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-ai-brain
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "ai-brain",
+ AppClientId: "APP_rafnuCAmBESIVYMH"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-splice
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "splice",
+ AppClientId: "APP_zE0M3sTRXrCIJS8Y"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-smauth
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "smauth",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-visualization
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "visualization",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-uasms
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "uasms",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-classification
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "classification",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-mianyangbackend
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "mianyangbackend",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-dikongzhixingh5
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "dikongzhixingh5",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-supervision
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "supervision",
+ AppClientId: "APP_qqSu82THfexI8PLM"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-mws
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "mws",
+ AppClientId: "APP_uKniXPELlRERBBwK"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-security
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "security",
+ AppClientId: "APP_JUSEMc7afyWXxvE7"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-scanner
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "scanner",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-eventsh5
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "eventsh5",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-detection
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "detection",
+ AppClientId: "APP_FDHW2VLVDWPnnOCy"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-emergency
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "emergency",
+ AppClientId: "APP_aGsTAY1uMZrpKdfk"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-seniclive
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "seniclive",
+ AppClientId: "empty"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-supervisionh5
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "supervisionh5",
+ AppClientId: "APP_qqSu82THfexI8PLM"
+ }
+---
+kind: ConfigMap
+apiVersion: v1
+metadata:
+ name: tenant-prefix-hljtt
+ namespace: uavcloud-devflight
+data:
+ ingress-config.js: |-
+ var __GlobalIngressConfig = {
+ TenantEnvironment: "devflight",
+ CloudHOST: "lab.uavcmlc.com",
+ ApplicationShortName: "hljtt",
AppClientId: "empty"
}
diff --git a/agent-common/real_project/uavcloud-devflight/old/k8s-frontend.yaml b/agent-common/real_project/uavcloud-devflight/old/k8s-frontend.yaml
index 1ed05f2..41925aa 100644
--- a/agent-common/real_project/uavcloud-devflight/old/k8s-frontend.yaml
+++ b/agent-common/real_project/uavcloud-devflight/old/k8s-frontend.yaml
@@ -27,456 +27,11 @@ data:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-emergency-rescue
+ name: cmii-uav-platform-uasms
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-emergency-rescue
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-emergency-rescue:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-emergency-rescue
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-emergency
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-emergency-rescue
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-emergency-rescue
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-classification
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-classification
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-classification:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-classification
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-classification
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-classification
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-classification
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-logistics
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-logistics
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-logistics
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-logistics
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-logistics
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-logistics:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-logistics
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-logistics
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-logistics
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-logistics
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-logistics
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-media
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-media
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-media:5.7.0-v2
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-media
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-media
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-media
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-media
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-base
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-base
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-base:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-base
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-base
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-base
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-base
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-uas
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
+ cmii.app: cmii-uav-platform-uasms
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -487,24 +42,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
+ cmii.app: cmii-uav-platform-uasms
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
+ cmii.app: cmii-uav-platform-uasms
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-uas
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-uas:5.7.0-snapshot
+ - name: cmii-uav-platform-uasms
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-uasms:master-1.1.0-250117
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-uas
+ value: cmii-uav-platform-uasms
ports:
- name: platform-9528
containerPort: 9528
@@ -532,7 +87,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-uas
+ name: tenant-prefix-uasms
items:
- key: ingress-config.js
path: ingress-config.js
@@ -540,107 +95,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-uas
+ name: cmii-uav-platform-uasms
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
+ cmii.app: cmii-uav-platform-uasms
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-uas
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-oms
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-oms
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-oms:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-oms
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-oms
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-oms
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-oms
+ cmii.app: cmii-uav-platform-uasms
ports:
- name: web-svc-port
port: 9528
@@ -739,11 +205,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-pilot2-to-cloud
+ name: cmii-uav-platform-open
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
+ cmii.app: cmii-uav-platform-open
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -754,24 +220,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
+ cmii.app: cmii-uav-platform-open
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
+ cmii.app: cmii-uav-platform-open
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-pilot2-to-cloud
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-pilot2-to-cloud:5.7.0-snapshot
+ - name: cmii-uav-platform-open
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-open:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-pilot2-to-cloud
+ value: cmii-uav-platform-open
ports:
- name: platform-9528
containerPort: 9528
@@ -799,7 +265,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-pilot2cloud
+ name: tenant-prefix-open
items:
- key: ingress-config.js
path: ingress-config.js
@@ -807,18 +273,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-pilot2-to-cloud
+ name: cmii-uav-platform-open
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
+ cmii.app: cmii-uav-platform-open
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-pilot2-to-cloud
+ cmii.app: cmii-uav-platform-open
ports:
- name: web-svc-port
port: 9528
@@ -828,100 +294,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-jiangsuwenlv
+ name: cmii-uav-platform-armypeople
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-jiangsuwenlv
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-jiangsuwenlv:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-jiangsuwenlv
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-jiangsuwenlv
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-jiangsuwenlv
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-jiangsuwenlv
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-blockchain
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
+ cmii.app: cmii-uav-platform-armypeople
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -932,24 +309,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
+ cmii.app: cmii-uav-platform-armypeople
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
+ cmii.app: cmii-uav-platform-armypeople
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-blockchain
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-blockchain:5.7.0-snapshot
+ - name: cmii-uav-platform-armypeople
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-armypeople:5.7.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-blockchain
+ value: cmii-uav-platform-armypeople
ports:
- name: platform-9528
containerPort: 9528
@@ -977,7 +354,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-blockchain
+ name: tenant-prefix-armypeople
items:
- key: ingress-config.js
path: ingress-config.js
@@ -985,18 +362,463 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-blockchain
+ name: cmii-uav-platform-armypeople
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
+ cmii.app: cmii-uav-platform-armypeople
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-blockchain
+ cmii.app: cmii-uav-platform-armypeople
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-media
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-media
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-media:5.7.0-v2
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-media
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-media
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-media
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-media
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-pangu
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uavms-platform-security-center
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uavms-platform-security-center
+ image: harbor.cdcyy.com.cn/cmii/cmii-uavms-platform-security-center:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uavms-platform-security-center
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-secenter
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uavms-platform-security-center
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uavms-platform-security-center
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-smauth
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-smauth
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-smauth:6.0.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-smauth
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-smauth
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-smauth
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smauth
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-classification
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-classification
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-classification:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-classification
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-classification
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-classification
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-classification
ports:
- name: web-svc-port
port: 9528
@@ -1183,1163 +1005,6 @@ spec:
---
apiVersion: apps/v1
kind: Deployment
-metadata:
- name: cmii-uav-platform-securityh5
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-securityh5
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-securityh5:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-securityh5
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-securityh5
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-securityh5
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-securityh5
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uavms-platform-manager
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-manager
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-manager
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-manager
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uavms-platform-manager
- image: harbor.cdcyy.com.cn/cmii/cmii-uavms-platform-manager:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uavms-platform-manager
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-uavmsmanager
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uavms-platform-manager
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-manager
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-manager
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-dispatchh5
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-dispatchh5
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-dispatchh5
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-dispatchh5
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-dispatchh5
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-dispatchh5:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-dispatchh5
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-dispatchh5
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-dispatchh5
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-dispatchh5
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-dispatchh5
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-cms-portal
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-cms-portal
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-cms-portal:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-cms-portal
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-cmsportal
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-cms-portal
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-cms-portal
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform:5.7.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-pangu
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-security
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-security
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-security
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-security
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-security
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-security:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-security
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-security
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-security
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-security
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-security
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-qingdao
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-qingdao
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-qingdao:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-qingdao
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-qingdao
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-qingdao
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qingdao
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uavms-platform-security-center
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uavms-platform-security-center
- image: harbor.cdcyy.com.cn/cmii/cmii-uavms-platform-security-center:6.0.0-snapshot
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uavms-platform-security-center
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-secenter
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uavms-platform-security-center
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uavms-platform-security-center
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-scanner
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-scanner
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-scanner:5.5.0-integration
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-scanner
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-scanner
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-scanner
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-scanner
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-ai-brain
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-ai-brain
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-ai-brain
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-ai-brain
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-ai-brain
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-ai-brain:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-ai-brain
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-ai-brain
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-ai-brain
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-ai-brain
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-ai-brain
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-open
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 1
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-open
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-open:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-open
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-open
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-open
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-open
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-qinghaitourism
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qinghaitourism
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qinghaitourism
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qinghaitourism
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-qinghaitourism
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-qinghaitourism:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-qinghaitourism
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-qinghaitourism
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-qinghaitourism
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qinghaitourism
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-qinghaitourism
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-hljtt
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-hljtt
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-hljtt:5.6.0
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-hljtt
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-hljtt
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-hljtt
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-hljtt
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
metadata:
name: cmii-uav-platform-seniclive
namespace: uavcloud-devflight
@@ -2430,11 +1095,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-suav-platform-supervisionh5
+ name: cmii-uav-platform-awareness
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervisionh5
+ cmii.app: cmii-uav-platform-awareness
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -2445,24 +1110,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervisionh5
+ cmii.app: cmii-uav-platform-awareness
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervisionh5
+ cmii.app: cmii-uav-platform-awareness
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-suav-platform-supervisionh5
- image: harbor.cdcyy.com.cn/cmii/cmii-suav-platform-supervisionh5:5.6.0
+ - name: cmii-uav-platform-awareness
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-awareness:6.0.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-suav-platform-supervisionh5
+ value: cmii-uav-platform-awareness
ports:
- name: platform-9528
containerPort: 9528
@@ -2490,7 +1155,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-supervisionh5
+ name: tenant-prefix-awareness
items:
- key: ingress-config.js
path: ingress-config.js
@@ -2498,18 +1163,196 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-suav-platform-supervisionh5
+ name: cmii-uav-platform-awareness
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervisionh5
+ cmii.app: cmii-uav-platform-awareness
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-suav-platform-supervisionh5
+ cmii.app: cmii-uav-platform-awareness
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-oms
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-oms
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-oms
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-oms
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-oms
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-oms:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-oms
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-oms
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-oms
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-oms
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-oms
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-pilot2-to-cloud
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-pilot2-to-cloud
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-pilot2-to-cloud:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-pilot2-to-cloud
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-pilot2cloud
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-pilot2-to-cloud
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-pilot2-to-cloud
ports:
- name: web-svc-port
port: 9528
@@ -2608,11 +1451,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-hyperspectral
+ name: cmii-uav-platform-securityh5
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-securityh5
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -2623,24 +1466,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-securityh5
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-securityh5
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-hyperspectral
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-hyperspectral:5.7.0-snapshot
+ - name: cmii-uav-platform-securityh5
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-securityh5:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-hyperspectral
+ value: cmii-uav-platform-securityh5
ports:
- name: platform-9528
containerPort: 9528
@@ -2668,7 +1511,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-hyper
+ name: tenant-prefix-securityh5
items:
- key: ingress-config.js
path: ingress-config.js
@@ -2676,18 +1519,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-hyperspectral
+ name: cmii-uav-platform-securityh5
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-securityh5
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-hyperspectral
+ cmii.app: cmii-uav-platform-securityh5
ports:
- name: web-svc-port
port: 9528
@@ -2697,39 +1540,39 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-smauth
+ name: cmii-uav-platform-hljtt
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
+ cmii.app: cmii-uav-platform-hljtt
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
- replicas: 1
+ replicas: 0
strategy:
rollingUpdate:
maxUnavailable: 1
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
+ cmii.app: cmii-uav-platform-hljtt
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
+ cmii.app: cmii-uav-platform-hljtt
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-smauth
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-smauth:6.0.0-snapshot
+ - name: cmii-uav-platform-hljtt
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-hljtt:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-smauth
+ value: cmii-uav-platform-hljtt
ports:
- name: platform-9528
containerPort: 9528
@@ -2757,7 +1600,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-smauth
+ name: tenant-prefix-hljtt
items:
- key: ingress-config.js
path: ingress-config.js
@@ -2765,18 +1608,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-smauth
+ name: cmii-uav-platform-hljtt
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
+ cmii.app: cmii-uav-platform-hljtt
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smauth
+ cmii.app: cmii-uav-platform-hljtt
ports:
- name: web-svc-port
port: 9528
@@ -2786,11 +1629,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-armypeople
+ name: cmii-uav-platform-base
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
+ cmii.app: cmii-uav-platform-base
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -2801,24 +1644,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
+ cmii.app: cmii-uav-platform-base
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
+ cmii.app: cmii-uav-platform-base
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-armypeople
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-armypeople:5.7.0-snapshot
+ - name: cmii-uav-platform-base
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-base:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-armypeople
+ value: cmii-uav-platform-base
ports:
- name: platform-9528
containerPort: 9528
@@ -2846,7 +1689,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-armypeople
+ name: tenant-prefix-base
items:
- key: ingress-config.js
path: ingress-config.js
@@ -2854,18 +1697,552 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-armypeople
+ name: cmii-uav-platform-base
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
+ cmii.app: cmii-uav-platform-base
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-armypeople
+ cmii.app: cmii-uav-platform-base
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-cms-portal
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-cms-portal
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-cms-portal
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-cms-portal
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-cms-portal
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-cms-portal:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-cms-portal
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-cmsportal
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-cms-portal
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-cms-portal
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-cms-portal
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-uas
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-uas
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-uas:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-uas
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-uas
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-uas
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-uas
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-blockchain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-blockchain
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-blockchain:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-blockchain
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-blockchain
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-blockchain
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-blockchain
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-smsecret
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-smsecret
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-smsecret:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-smsecret
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-smsecret
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-smsecret
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-smsecret
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-scanner
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-scanner
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-scanner:5.5.0-integration
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-scanner
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-scanner
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-scanner
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-scanner
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-logistics
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-logistics
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-logistics
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-logistics
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-logistics
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-logistics:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-logistics
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-logistics
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-logistics
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-logistics
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-logistics
ports:
- name: web-svc-port
port: 9528
@@ -2964,100 +2341,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-uasms
+ name: cmii-uav-platform-ai-brain
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- octopus.control: frontend-app-wdd
- app.kubernetes.io/app-version: 6.0.0
-spec:
- replicas: 0
- strategy:
- rollingUpdate:
- maxUnavailable: 1
- selector:
- matchLabels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- template:
- metadata:
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- spec:
- imagePullSecrets:
- - name: harborsecret
- containers:
- - name: cmii-uav-platform-uasms
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-uasms:master-1.1.0-250117
- imagePullPolicy: Always
- env:
- - name: K8S_NAMESPACE
- value: uavcloud-devflight
- - name: APPLICATION_NAME
- value: cmii-uav-platform-uasms
- ports:
- - name: platform-9528
- containerPort: 9528
- protocol: TCP
- resources:
- limits:
- cpu: "1"
- memory: 1Gi
- requests:
- cpu: 50m
- memory: 50Mi
- volumeMounts:
- - name: nginx-conf
- mountPath: /etc/nginx/conf.d/nginx.conf
- subPath: nginx.conf
- - name: tenant-prefix
- subPath: ingress-config.js
- mountPath: /home/cmii-platform/dist/ingress-config.js
- volumes:
- - name: nginx-conf
- configMap:
- name: nginx-cm
- items:
- - key: nginx.conf
- path: nginx.conf
- - name: tenant-prefix
- configMap:
- name: tenant-prefix-uasms
- items:
- - key: ingress-config.js
- path: ingress-config.js
----
-apiVersion: v1
-kind: Service
-metadata:
- name: cmii-uav-platform-uasms
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- octopus.control: frontend-app-wdd
- app.kubernetes.io/version: 6.0.0
-spec:
- type: ClusterIP
- selector:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-uasms
- ports:
- - name: web-svc-port
- port: 9528
- protocol: TCP
- targetPort: 9528
----
-apiVersion: apps/v1
-kind: Deployment
-metadata:
- name: cmii-uav-platform-visualization
- namespace: uavcloud-devflight
- labels:
- cmii.type: frontend
- cmii.app: cmii-uav-platform-visualization
+ cmii.app: cmii-uav-platform-ai-brain
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -3068,24 +2356,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-visualization
+ cmii.app: cmii-uav-platform-ai-brain
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-visualization
+ cmii.app: cmii-uav-platform-ai-brain
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-visualization
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-visualization:5.6.0
+ - name: cmii-uav-platform-ai-brain
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-ai-brain:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-visualization
+ value: cmii-uav-platform-ai-brain
ports:
- name: platform-9528
containerPort: 9528
@@ -3113,7 +2401,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-visualization
+ name: tenant-prefix-ai-brain
items:
- key: ingress-config.js
path: ingress-config.js
@@ -3121,18 +2409,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-visualization
+ name: cmii-uav-platform-ai-brain
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-visualization
+ cmii.app: cmii-uav-platform-ai-brain
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-visualization
+ cmii.app: cmii-uav-platform-ai-brain
ports:
- name: web-svc-port
port: 9528
@@ -3142,11 +2430,11 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-multiterminal
+ name: cmii-uavms-platform-manager
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-multiterminal
+ cmii.app: cmii-uavms-platform-manager
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
@@ -3157,24 +2445,24 @@ spec:
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-multiterminal
+ cmii.app: cmii-uavms-platform-manager
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-multiterminal
+ cmii.app: cmii-uavms-platform-manager
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-multiterminal
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-multiterminal:5.6.0
+ - name: cmii-uavms-platform-manager
+ image: harbor.cdcyy.com.cn/cmii/cmii-uavms-platform-manager:6.0.0-snapshot
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-multiterminal
+ value: cmii-uavms-platform-manager
ports:
- name: platform-9528
containerPort: 9528
@@ -3202,7 +2490,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-multiterminal
+ name: tenant-prefix-uavmsmanager
items:
- key: ingress-config.js
path: ingress-config.js
@@ -3210,18 +2498,18 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-multiterminal
+ name: cmii-uavms-platform-manager
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-multiterminal
+ cmii.app: cmii-uavms-platform-manager
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-multiterminal
+ cmii.app: cmii-uavms-platform-manager
ports:
- name: web-svc-port
port: 9528
@@ -3320,39 +2608,39 @@ spec:
apiVersion: apps/v1
kind: Deployment
metadata:
- name: cmii-uav-platform-smsecret
+ name: cmii-uav-platform-jiangsuwenlv
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
+ cmii.app: cmii-uav-platform-jiangsuwenlv
octopus.control: frontend-app-wdd
app.kubernetes.io/app-version: 6.0.0
spec:
- replicas: 1
+ replicas: 0
strategy:
rollingUpdate:
maxUnavailable: 1
selector:
matchLabels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
+ cmii.app: cmii-uav-platform-jiangsuwenlv
template:
metadata:
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
+ cmii.app: cmii-uav-platform-jiangsuwenlv
spec:
imagePullSecrets:
- name: harborsecret
containers:
- - name: cmii-uav-platform-smsecret
- image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-smsecret:5.7.0-snapshot
+ - name: cmii-uav-platform-jiangsuwenlv
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-jiangsuwenlv:5.6.0
imagePullPolicy: Always
env:
- name: K8S_NAMESPACE
value: uavcloud-devflight
- name: APPLICATION_NAME
- value: cmii-uav-platform-smsecret
+ value: cmii-uav-platform-jiangsuwenlv
ports:
- name: platform-9528
containerPort: 9528
@@ -3380,7 +2668,7 @@ spec:
path: nginx.conf
- name: tenant-prefix
configMap:
- name: tenant-prefix-smsecret
+ name: tenant-prefix-jiangsuwenlv
items:
- key: ingress-config.js
path: ingress-config.js
@@ -3388,18 +2676,819 @@ spec:
apiVersion: v1
kind: Service
metadata:
- name: cmii-uav-platform-smsecret
+ name: cmii-uav-platform-jiangsuwenlv
namespace: uavcloud-devflight
labels:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
+ cmii.app: cmii-uav-platform-jiangsuwenlv
octopus.control: frontend-app-wdd
app.kubernetes.io/version: 6.0.0
spec:
type: ClusterIP
selector:
cmii.type: frontend
- cmii.app: cmii-uav-platform-smsecret
+ cmii.app: cmii-uav-platform-jiangsuwenlv
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-security
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-security
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-security:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-security
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-security
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-security
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-security
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-suav-platform-supervisionh5
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervisionh5
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervisionh5
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervisionh5
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-suav-platform-supervisionh5
+ image: harbor.cdcyy.com.cn/cmii/cmii-suav-platform-supervisionh5:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-suav-platform-supervisionh5
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-supervisionh5
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-suav-platform-supervisionh5
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervisionh5
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-suav-platform-supervisionh5
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-qingdao
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-qingdao
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-qingdao:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-qingdao
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-qingdao
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-qingdao
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qingdao
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-dispatchh5
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-dispatchh5
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-dispatchh5
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-dispatchh5
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-dispatchh5
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-dispatchh5:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-dispatchh5
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-dispatchh5
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-dispatchh5
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-dispatchh5
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-dispatchh5
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-qinghaitourism
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qinghaitourism
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 0
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qinghaitourism
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qinghaitourism
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-qinghaitourism
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-qinghaitourism:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-qinghaitourism
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-qinghaitourism
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-qinghaitourism
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qinghaitourism
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-qinghaitourism
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-visualization
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-visualization
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-visualization
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-visualization
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-visualization
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-visualization:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-visualization
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-visualization
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-visualization
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-visualization
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-visualization
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-emergency-rescue
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-emergency-rescue
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-emergency-rescue
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-emergency-rescue
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-emergency-rescue
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-emergency-rescue:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-emergency-rescue
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-emergency
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-emergency-rescue
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-emergency-rescue
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-emergency-rescue
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-multiterminal
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-multiterminal
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-multiterminal
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-multiterminal
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-multiterminal
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-multiterminal:5.6.0
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-multiterminal
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-multiterminal
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-multiterminal
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-multiterminal
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-multiterminal
+ ports:
+ - name: web-svc-port
+ port: 9528
+ protocol: TCP
+ targetPort: 9528
+---
+apiVersion: apps/v1
+kind: Deployment
+metadata:
+ name: cmii-uav-platform-hyperspectral
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/app-version: 6.0.0
+spec:
+ replicas: 1
+ strategy:
+ rollingUpdate:
+ maxUnavailable: 1
+ selector:
+ matchLabels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ template:
+ metadata:
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ spec:
+ imagePullSecrets:
+ - name: harborsecret
+ containers:
+ - name: cmii-uav-platform-hyperspectral
+ image: harbor.cdcyy.com.cn/cmii/cmii-uav-platform-hyperspectral:5.7.0-snapshot
+ imagePullPolicy: Always
+ env:
+ - name: K8S_NAMESPACE
+ value: uavcloud-devflight
+ - name: APPLICATION_NAME
+ value: cmii-uav-platform-hyperspectral
+ ports:
+ - name: platform-9528
+ containerPort: 9528
+ protocol: TCP
+ resources:
+ limits:
+ cpu: "1"
+ memory: 1Gi
+ requests:
+ cpu: 50m
+ memory: 50Mi
+ volumeMounts:
+ - name: nginx-conf
+ mountPath: /etc/nginx/conf.d/nginx.conf
+ subPath: nginx.conf
+ - name: tenant-prefix
+ subPath: ingress-config.js
+ mountPath: /home/cmii-platform/dist/ingress-config.js
+ volumes:
+ - name: nginx-conf
+ configMap:
+ name: nginx-cm
+ items:
+ - key: nginx.conf
+ path: nginx.conf
+ - name: tenant-prefix
+ configMap:
+ name: tenant-prefix-hyper
+ items:
+ - key: ingress-config.js
+ path: ingress-config.js
+---
+apiVersion: v1
+kind: Service
+metadata:
+ name: cmii-uav-platform-hyperspectral
+ namespace: uavcloud-devflight
+ labels:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
+ octopus.control: frontend-app-wdd
+ app.kubernetes.io/version: 6.0.0
+spec:
+ type: ClusterIP
+ selector:
+ cmii.type: frontend
+ cmii.app: cmii-uav-platform-hyperspectral
ports:
- name: web-svc-port
port: 9528
diff --git a/agent-common/real_project/uavcloud-devflight/old/k8s-ingress.yaml b/agent-common/real_project/uavcloud-devflight/old/k8s-ingress.yaml
index c70c9fa..0909901 100644
--- a/agent-common/real_project/uavcloud-devflight/old/k8s-ingress.yaml
+++ b/agent-common/real_project/uavcloud-devflight/old/k8s-ingress.yaml
@@ -19,6 +19,7 @@ metadata:
rewrite ^(/pangu)$ $1/ redirect;
rewrite ^(/ai-brain)$ $1/ redirect;
rewrite ^(/armypeople)$ $1/ redirect;
+ rewrite ^(/awareness)$ $1/ redirect;
rewrite ^(/base)$ $1/ redirect;
rewrite ^(/blockchain)$ $1/ redirect;
rewrite ^(/classification)$ $1/ redirect;
@@ -92,6 +93,11 @@ spec:
backend:
serviceName: cmii-uav-platform-armypeople
servicePort: 9528
+ - path: /devflight/awareness/?(.*)
+ pathType: ImplementationSpecific
+ backend:
+ serviceName: cmii-uav-platform-awareness
+ servicePort: 9528
- path: /devflight/base/?(.*)
pathType: ImplementationSpecific
backend:
diff --git a/agent-deploy/d_app/CmiiImageConfig.go b/agent-deploy/d_app/CmiiImageConfig.go
index bc38216..b2c5a78 100755
--- a/agent-deploy/d_app/CmiiImageConfig.go
+++ b/agent-deploy/d_app/CmiiImageConfig.go
@@ -52,6 +52,7 @@ var CmiiBackendAppMap = map[string]string{
"cmii-sky-converge": "5.7.0",
"cmii-uav-sec-awareness": "5.7.0",
"cmii-uav-security-trace": "5.7.0",
+ "cmii-uavms-pyfusion": "5.7.0",
}
var CmiiFrontendAppMap = map[string]string{
@@ -88,6 +89,7 @@ var CmiiFrontendAppMap = map[string]string{
"cmii-uav-platform-dispatchh5": "5.2.0",
"cmii-uavms-platform-manager": "5.2.0",
"cmii-uav-platform-awareness": "5.2.0",
+ "cmii-uav-platform-flight-control": "5.2.0",
}
var IgnoreCmiiBackendAppName = map[string]string{
@@ -175,6 +177,10 @@ var MiddlewareAmd64 = []string{
"docker.107421.xyz/jerrychina2020/rke-tools:v0.175-linux",
"docker.107421.xyz/jerrychina2020/rke-tools:v0.175",
"docker.107421.xyz/library/busybox:latest",
+ "harbor.cdcyy.com.cn/cmii/doris.be-ubuntu:2.1.6",
+ "harbor.cdcyy.com.cn/cmii/doris.be-ubuntu:2.1.6",
+ "harbor.cdcyy.com.cn/cmii/doris.k8s-operator:1.3.1",
+ "harbor.cdcyy.com.cn/cmii/alpine:latest",
}
var Rancher1204Amd64 = []string{
diff --git a/agent-deploy/d_app/FrontendConfigMap.go b/agent-deploy/d_app/FrontendConfigMap.go
index ba2ddd7..6d7df08 100755
--- a/agent-deploy/d_app/FrontendConfigMap.go
+++ b/agent-deploy/d_app/FrontendConfigMap.go
@@ -45,6 +45,7 @@ var FrontendShortNameMaps = map[string]string{
"cmii-uavms-platform-manager": "uavmsmanager",
"cmii-uav-platform-renyike": "renyike",
"cmii-uav-platform-awareness": "awareness",
+ "cmii-uav-platform-flight-control": "flight-control",
}
var FrontendClientIdMaps = map[string]string{
@@ -92,4 +93,5 @@ var FrontendClientIdMaps = map[string]string{
"cmii-uavms-platform-manager": "empty",
"cmii-uav-platform-renyike": "empty",
"cmii-uav-platform-awareness": "empty",
+ "cmii-uav-platform-flight-control": "empty",
}
diff --git a/agent-operator/CmiiImageSyncOperator_test.go b/agent-operator/CmiiImageSyncOperator_test.go
index 0b66490..5669b62 100644
--- a/agent-operator/CmiiImageSyncOperator_test.go
+++ b/agent-operator/CmiiImageSyncOperator_test.go
@@ -10,57 +10,57 @@ import (
*/
func TestFetchDependencyRepos_Middle(t *testing.T) {
-
- errorPullImageList, errorGzipImageList, realCmiiImageName, allGzipFileNameList := C_DownloadCompressUploadDependency(true, false, false)
-
+
+ errorPullImageList, errorGzipImageList, realCmiiImageName, allGzipFileNameList := C_DownloadCompressUploadDependency(true, true, false)
+
utils.BeautifulPrintListWithTitle(errorPullImageList, "errorPullImageList")
utils.BeautifulPrintListWithTitle(errorGzipImageList, "errorGzipImageList")
utils.BeautifulPrintListWithTitle(realCmiiImageName, "realCmiiImageName")
utils.BeautifulPrintListWithTitle(allGzipFileNameList, "allGzipFileNameList")
-
+
}
func TestFetchDependencyRepos_RKE(t *testing.T) {
-
+
errorPullImageList, errorGzipImageList, realCmiiImageName, allGzipFileNameList := C_DownloadCompressUploadDependency(true, false, true)
-
+
utils.BeautifulPrintListWithTitle(errorPullImageList, "errorPullImageList")
utils.BeautifulPrintListWithTitle(errorGzipImageList, "errorGzipImageList")
utils.BeautifulPrintListWithTitle(realCmiiImageName, "realCmiiImageName")
utils.BeautifulPrintListWithTitle(allGzipFileNameList, "allGzipFileNameList")
-
+
}
func TestLoadSplitGzipImageToTargetHarbor(t *testing.T) {
errorLoadImageNameList, errorPushImageNameList := LoadSplitCmiiGzipImageToTargetHarbor("xmyd", DirectPushDeployHarborHost)
-
+
utils.BeautifulPrintListWithTitle(errorLoadImageNameList, "errorLoadImageNameList")
utils.BeautifulPrintListWithTitle(errorPushImageNameList, "errorPushImageNameList")
}
func TestLoadSplitDepGzipImageToTargetHarbor(t *testing.T) {
errorLoadImageNameList, errorPushImageNameList := LoadSplitDepGzipImageToTargetHarbor(DirectPushDeployHarborHost)
-
+
utils.BeautifulPrintListWithTitle(errorLoadImageNameList, "errorLoadImageNameList")
utils.BeautifulPrintListWithTitle(errorPushImageNameList, "errorPushImageNameList")
}
func TestPullFromEntityAndSyncConditionally(t *testing.T) {
-
+
// 下载镜像的核心函数
sync := ImageSyncEntity{
DownloadCondition: &DownloadEntity{
ShouldDownloadImage: true,
ProjectName: "6.2.0_demo",
ProjectVersion: "6.2.0-demo",
- CmiiNameTagList: []string{
+ CmiiNameTagList: []string{
//"cmii-uav-mqtthandler:5.4.0-bjdyt-052102",
},
- FullNameImageList: []string{},
+ FullNameImageList: []string{},
DownloadAuthUserName: "",
DownloadAuthPassword: "",
},
-
+
CompressCondition: &CompressEntity{
ShouldCompressImageToGzip: true,
ShouldGzipSplit: true,
@@ -72,12 +72,12 @@ func TestPullFromEntityAndSyncConditionally(t *testing.T) {
DirectHarborHost: "harbor.wdd.io:8033",
ShouldDirectPushToHarbor: false,
}
-
+
// 调用函数并获取结果。这里需要根据你的实际需求来验证返回的结果是否符合预期。
result := sync.PullFromEntityAndSyncConditionally()
-
+
utils.BeautifulPrint(result)
-
+
// 添加断言以检查函数的输出,例如:
// ...其他验证逻辑...
}
@@ -89,7 +89,7 @@ func TestPullFromEntityAndSyncConditionally_ChongQingErJiPingTai(t *testing.T) {
ShouldDownloadImage: true,
ProjectName: "cqejpt",
ProjectVersion: "",
- CmiiNameTagList: []string{
+ CmiiNameTagList: []string{
//"cmii-uav-mqtthandler:5.4.0-bjdyt-052102",
},
FullNameImageList: []string{
@@ -158,7 +158,7 @@ func TestPullFromEntityAndSyncConditionally_ChongQingErJiPingTai(t *testing.T) {
DownloadAuthUserName: "",
DownloadAuthPassword: "",
},
-
+
CompressCondition: &CompressEntity{
ShouldCompressImageToGzip: false,
ShouldGzipSplit: true,
@@ -170,43 +170,43 @@ func TestPullFromEntityAndSyncConditionally_ChongQingErJiPingTai(t *testing.T) {
DirectHarborHost: "chongqingshcis-a189ec98.ecis.chongqing-1.cmecloud.cn",
ShouldDirectPushToHarbor: true,
}
-
+
// 调用函数并获取结果。这里需要根据你的实际需求来验证返回的结果是否符合预期。
result := sync.PullFromEntityAndSyncConditionally()
-
+
utils.BeautifulPrint(result)
-
+
// 添加断言以检查函数的输出,例如:
// ...其他验证逻辑...
}
func TestDownloadLoadTagUpload(t *testing.T) {
-
+
localGzipFileList := []string{
"/root/octopus_image/middle",
"/root/octopus_image/rke",
"/root/octopus_image/xjyd",
}
-
+
for _, s := range localGzipFileList {
log.InfoF("start to sync => %s", s)
-
+
targetImageFullNameList := A_DownloadLoadTagUpload(false, "", "", s, "172.28.0.251:8033")
-
+
utils.BeautifulPrintListWithTitle(targetImageFullNameList, "targetImageFullNameList")
-
+
}
-
+
}
func TestConcatAndUniformCmiiImage(t *testing.T) {
// 创建一个模拟的fullImageList和cmiiImageList,用于测试函数的行为。这里需要根据你的实际需求来设置mock数据和预期结果。
fullImageList := []string{"image3", "image4"}
cmiiImageList := []string{"image1", "image2"}
-
+
// 调用函数并获取结果。这里需要根据你的实际需求来验证返回的结果是否符合预期。
result := concatAndUniformCmiiImage(fullImageList, cmiiImageList)
-
+
// 添加断言以检查函数的输出,例如:
expectedResult := []string{"image3", "image4", image2.CmiiHarborPrefix + "image1", image2.CmiiHarborPrefix + "image2"}
if len(result) != len(expectedResult) {
@@ -228,9 +228,9 @@ func TestImageSyncEntity_PullFromEntityAndSyncConditionally(t *testing.T) {
},
DirectHarborHost: "36.134.71.138",
}
-
+
imageSyncResult := imageSyncEntity.PullFromEntityAndSyncConditionally()
-
+
utils.BeautifulPrint(imageSyncResult)
-
+
}
diff --git a/agent-wdd/config/Network.go b/agent-wdd/config/Network.go
index 5e23bd4..30a9a48 100644
--- a/agent-wdd/config/Network.go
+++ b/agent-wdd/config/Network.go
@@ -154,16 +154,17 @@ func judgeCanConnectInternet() int {
// GetPublicInfo 获取服务器的公网信息
func (p PublicInfo) GetPublicInfo() PublicInfo {
- if CanConnectInternet() == InternetBaseLine {
- // 无法联网, 假信息
+ // 无法联网, 假信息
+ fakePublicInfo := PublicInfo{
+ IPv4: "1.1.1.1",
+ IPv6: "2400::1",
+ Country: "CN",
+ City: "Shanghai",
+ ASN: "Wdd Inc",
+ Timezone: "Asia/Shanghai",
+ }
- fakePublicInfo := PublicInfo{
- IPv4: "1.1.1.1",
- IPv6: "2400::1",
- Country: "CN",
- City: "Shanghai",
- ASN: "Wdd Inc",
- }
+ if CanConnectInternet() == InternetBaseLine {
// 持久化保存
ConfigCache.Agent.Network.Public = fakePublicInfo
@@ -181,6 +182,8 @@ func (p PublicInfo) GetPublicInfo() PublicInfo {
req, err := http.NewRequest("GET", "https://ipinfo.io", nil)
if err != nil {
log.Error("创建请求失败: %v", err)
+ return fakePublicInfo
+
}
// 设置请求头
@@ -190,7 +193,8 @@ func (p PublicInfo) GetPublicInfo() PublicInfo {
// 发送请求
resp, err := client.Do(req)
if err != nil {
- log.Error("请求PublicInfo失败: %v", err)
+ log.Error("请求PublicInfo失败: %s", err.Error())
+ return fakePublicInfo
}
defer resp.Body.Close()
diff --git a/agent-wdd/test/run_test.sh b/agent-wdd/test/run_test.sh
index 06ef3ee..94d2664 100644
--- a/agent-wdd/test/run_test.sh
+++ b/agent-wdd/test/run_test.sh
@@ -3,12 +3,12 @@
rm -f /usr/local/bin/agent-wdd
rm -f /usr/local/bin/test-shell.sh
-wget https://pan.107421.xyz/d/oracle-seoul-2/agent-wdd_linux_amd64 -O /usr/local/bin/agent-wdd
+wget https://pan.107421.xyz/d/oracle-seoul-2/agent-wdd_linux_amd64 -qO /usr/local/bin/agent-wdd
chmod +x /usr/local/bin/agent-wdd
-wget https://pan.107421.xyz/d/oracle-seoul-2/test-shell.sh -O /usr/local/bin/test-shell.sh
+wget https://pan.107421.xyz/d/oracle-seoul-2/test-shell.sh -qO /usr/local/bin/test-shell.sh
chmod +x /usr/local/bin/test-shell.sh