রিসোর্স লোড হচ্ছে... লোডিং...

ডায়াল

আদিম জন্যSocketঅ্যাক্সেস, সমর্থনtcp, udp, tls, unixচারটি জনপ্রিয় যোগাযোগ প্রোটোকল সমর্থন করেঃmqtt, nats, amqp, kafka. ডাটাবেসের সাথে সংযোগের জন্য সমর্থনঃsqlite3, mysql, postgres, clickhouse.

দ্যDial()ফাংশনটি যদি এটি টাইম আউট করে তবে শূন্য ফেরত দেয়। একটি সাধারণ কল একটি সংযোগ অবজেক্ট ফেরত দেয় যার তিনটি পদ্ধতি রয়েছেঃread, writeএবংclose.readপদ্ধতিটি ডেটা পড়তে ব্যবহৃত হয়,writeতথ্য পাঠানোর জন্য ব্যবহৃত হয় এবংcloseসংযোগ বন্ধ করতে এই পদ্ধতি ব্যবহার করা হয়। দ্যreadপদ্ধতি নিম্নলিখিত পরামিতি সমর্থন করেঃ

  • যখন কোন প্যারামিটার পাস করা হয় না, এটি একটি বার্তা পাওয়া যায় এবং ফেরত পর্যন্ত ব্লক, যেমনws.read().
  • যখন একটি পরামিতি হিসাবে পাস করা হয়, তখন ইউনিটটি মিলিসেকেন্ড হয়, বার্তার অপেক্ষা টাইমআউট সময় নির্দিষ্ট করে। উদাহরণস্বরূপঃws.read(2000)দুই সেকেন্ডের টাইমআউট (২০০০ মিলিসেকেন্ড) নির্দিষ্ট করে।
  • নিম্নলিখিত দুটি পরামিতি শুধুমাত্র WebSocket এর জন্য বৈধঃ প্যারামিটার পাস করা হচ্ছে-1মানে ফাংশনটি অবিলম্বে বার্তাগুলির উপস্থিতি বা অনুপস্থিতি নির্বিশেষে ফেরত দেয়, উদাহরণস্বরূপঃws.read(-1). প্যারামিটার পাস করা হচ্ছে-2এর মানে হল যে ফাংশনটি অবিলম্বে একটি বার্তা সহ বা ছাড়াই ফিরে আসে, তবে কেবলমাত্র সর্বশেষ বার্তাটি ফিরে আসে এবং বাফারযুক্ত বার্তাটি বাদ দেওয়া হয়। উদাহরণস্বরূপ,ws.read(-2).

read()ফাংশন বাফারের বর্ণনাঃ ওয়েবসকেট প্রোটোকলের দ্বারা প্রেরিত ইনকামিং ডেটা যদি কৌশলটির মধ্যে সময়ের ব্যবধানread()ফাংশন কলগুলি খুব দীর্ঘ। এই ডেটাগুলি বাফারে সংরক্ষণ করা হয়, যার সর্বাধিক 2000 এর সাথে একটি সারি ডেটা কাঠামো রয়েছে। 2000 অতিক্রম করার পরে, সর্বশেষতম ডেটা বাফারে প্রবেশ করে এবং প্রাচীনতম ডেটা মুছে ফেলা হয়।

দৃশ্যকল্প কোন প্যারামিটার নেই প্যারামিটারঃ -1 প্যারামিটার: -২ প্যারামিটারঃ 2000 মিলিসেকেন্ডে
ডেটা ইতিমধ্যে বাফারে রয়েছে অবিলম্বে পুরোনো তথ্য ফেরত দিন অবিলম্বে পুরোনো তথ্য ফেরত দিন অবিলম্বে সর্বশেষ তথ্য ফেরত দিন অবিলম্বে পুরোনো তথ্য ফেরত দিন
বাফারে কোন তথ্য নেই ডাটা ব্লক করা হলে পুনরুদ্ধার করুন অবিলম্বে null ফেরত দিন অবিলম্বে null ফেরত দিন অপেক্ষা করুন 2000 এমএস, যদি কোন তথ্য না থাকে তাহলে null ফেরত দিন, যদি তথ্য থাকে তাহলে null ফেরত দিন
WebSocket সংযোগ সংযোগ বিচ্ছিন্ন বা পুনরায় সংযোগ করা হয় read() ফাংশন খালি স্ট্রিং ফেরত দেয়, যেমনঃ , এবং write() ফাংশন 0 ফেরত দেয়। পরিস্থিতি সনাক্ত করা হয়। আপনি close() ফাংশন ব্যবহার করে সংযোগ বন্ধ করতে পারেন, অথবা যদি আপনি স্বয়ংক্রিয় পুনরায় সংযোগ সেট আপ করেছেন, তাহলে আপনাকে এটি বন্ধ করার প্রয়োজন নেই, অন্তর্নিহিত সিস্টেম এটি স্বয়ংক্রিয়ভাবে পুনরায় সংযোগ করবে।

বস্তু

ডায়াল করুন (অ্যাড্রেস) ডায়াল (অ্যাড্রেস, টাইমআউট)

ঠিকানা চাই। ঠিকানা সত্য স্ট্রিং টাইমআউট সেকেন্ড, টাইমআউট মিথ্যা সংখ্যা

function main(){
    // Dial supports tcp://,udp://,tls://,unix://protocol, you can add a parameter to specify the number of seconds for the timeout
    var client = Dial("tls://www.baidu.com:443")  
    if (client) {
        // write can be followed by a numeric parameter to specify the timeout, write returns the number of bytes successfully sent
        client.write("GET / HTTP/1.1\nConnection: Closed\n\n")
        while (true) {
            // read can be followed by a numeric parameter specifying the timeout in milliseconds. Returning null indicates an error or timeout or that the socket has been closed
            var buf = client.read()
            if (!buf) {
                 break
            }
            Log(buf)
        }
        client.close()
    }
}
def main():
    client = Dial("tls://www.baidu.com:443")
    if client:
        client.write("GET / HTTP/1.1\nConnection: Closed\n\n")
        while True:
            buf = client.read()
            if not buf:
                break
            Log(buf)
        client.close()
void main() {
    auto client = Dial("tls://www.baidu.com:443");
    if(client.Valid) {
        client.write("GET / HTTP/1.1\nConnection: Closed\n\n");
        while(true) {
            auto buf = client.read();
            if(buf == "") {
                break;
            }
            Log(buf);
        }
        client.close();
    }
}

ডায়াল ফাংশন কলের উদাহরণঃ

function main() {
    LogStatus("Connecting...")
    // Accessing WebSocket interface of Binance
    var client = Dial("wss://stream.binance.com:9443/ws/!ticker@arr")
    if (!client) {
        Log("Connection failed, program exited")
        return
    }
    
    while (true) {
        // read returns only the data retrieved after the read call
        var buf = client.read()      
        if (!buf) {
            break
        }
        var table = {
            type: 'table',
            title: 'Ticker Chart',
            cols: ['Currency', 'Highest', 'Lowest', 'Buy 1', 'Sell 1', 'Last traded price', 'Volume', 'Update time'],
            rows: []
        }
        var obj = JSON.parse(buf)
        _.each(obj, function(ticker) {
            table.rows.push([ticker.s, ticker.h, ticker.l, ticker.b, ticker.a, ticker.c, ticker.q, _D(ticker.E)])
        })
        LogStatus('`' + JSON.stringify(table) + '`')
    }
    client.close()
}
import json
def main():
    LogStatus("Connecting...")
    client = Dial("wss://stream.binance.com:9443/ws/!ticker@arr")
    if not client:
        Log("Connection failed, program exited")
        return 
    
    while True:
        buf = client.read()
        if not buf:
            break
        table = {
            "type" : "table", 
            "title" : "Ticker Chart", 
            "cols" : ['Currency', 'Highest', 'Lowest', 'Buy 1', 'Sell 1', 'Last traded price', 'Volume', 'Update time'], 
            "rows" : [] 
        }
        obj = json.loads(buf)
        for i in range(len(obj)):
            table["rows"].append([obj[i]["s"], obj[i]["h"], obj[i]["l"], obj[i]["b"], obj[i]["a"], obj[i]["c"], obj[i]["q"], _D(int(obj[i]["E"]))])
        LogStatus('`' + json.dumps(table) + '`')
    client.close()
void main() {
    LogStatus("Connecting...");
    auto client = Dial("wss://stream.binance.com:9443/ws/!ticker@arr");
    if(!client.Valid) {
        Log("Connection failed, program exited");
        return;
    }
    
    while(true) {
        auto buf = client.read();
        if(buf == "") {
            break;
        }
        json table = R"({
            "type" : "table", 
            "title" : "Ticker Chart", 
            "cols" : ["Currency", "Highest", "Lowest", "Buy 1", "Sell 1", "Last traded price", "Volume", "Update time"], 
            "rows" : []
        })"_json;
        json obj = json::parse(buf);
        for(auto& ele : obj.items()) {
            table["rows"].push_back({ele.value()["s"], ele.value()["h"], ele.value()["l"], ele.value()["b"], ele.value()["a"], ele.value()["c"], 
                ele.value()["q"], _D(ele.value()["E"])});
        }
        LogStatus("`" + table.dump() + "`");
    }
    client.close();
}

বিন্যান্সের ওয়েবসকেট টিকার ইন্টারফেসে অ্যাক্সেস করতেঃ

var ws = null 
function main(){
    var param = {
        "op": "subscribe",
        "args": [{
            "channel": "tickers",
            "instId": "BTC-USDT"
        }]
    }
    // When calling Dial function, specify reconnect=true to set reconnection mode and payload to be the message sent when reconnecting. When the WebSocket connection is disconnected, it will reconnect and send messages automatically.
    ws = Dial("wss://ws.okx.com:8443/ws/v5/public|compress=gzip_raw&mode=recv&reconnect=true&payload="+ JSON.stringify(param))
    if(ws){
        var pingCyc = 1000 * 20
        var lastPingTime = new Date().getTime()
        while(true){
            var nowTime = new Date().getTime()
            var ret = ws.read()
            Log("ret:", ret)
            if(nowTime - lastPingTime > pingCyc){
                var retPing = ws.write("ping")
                lastPingTime = nowTime
                Log("Send : ping", "#FF0000")
            }
            LogStatus("Current time:", _D())
            Sleep(1000)
        }
    }
}              

function onexit() {
    ws.close() 
    Log("exit")
}
import json
import time              

ws = None
def main():
    global ws 
    param = {
        "op": "subscribe",
        "args": [{
            "channel": "tickers",
            "instId": "BTC-USDT"
        }]
    }
    ws = Dial("wss://ws.okx.com:8443/ws/v5/public|compress=gzip_raw&mode=recv&reconnect=true&payload=" + json.dumps(param))
    if ws:
        pingCyc = 1000 * 20
        lastPingTime = time.time() * 1000
        while True:
            nowTime = time.time() * 1000
            ret = ws.read()
            Log("ret:", ret)
            if nowTime - lastPingTime > pingCyc:
                retPing = ws.write("ping")
                lastPingTime = nowTime
                Log("Send: ping", "#FF0000")
            LogStatus("Current time:", _D())
            Sleep(1000)              

def onexit():
    ws.close()
    Log("exit")
auto objWS = Dial("wss://ws.okx.com:8443/ws/v5/public|compress=gzip_raw&mode=recv&reconnect=true");              

void main() {
    json param = R"({
        "op": "subscribe",
        "args": [{
            "channel": "tickers",
            "instId": "BTC-USDT"
        }]
    })"_json;
    
    objWS.write(param.dump());
    if(objWS.Valid) {
        uint64_t pingCyc = 1000 * 20;
        uint64_t lastPingTime = Unix() * 1000;
        while(true) {
            uint64_t nowTime = Unix() * 1000;
            auto ret = objWS.read();
            Log("ret:", ret);
            if(nowTime - lastPingTime > pingCyc) {
                auto retPing = objWS.write("ping");
                lastPingTime = nowTime;
                Log("Send: ping", "#FF0000");
            }
            LogStatus("Current time:", _D());
            Sleep(1000);
        }
    }
}              

void onexit() {
    objWS.close();
    Log("exit");
}

OKX এর ওয়েবসকেট টিকার ইন্টারফেসে অ্যাক্সেসঃ

var ws = null               

function main(){
    var param = {"sub": "market.btcusdt.detail", "id": "id1"}
    ws = Dial("wss://api.huobi.pro/ws|compress=gzip&mode=recv&reconnect=true&payload="+ JSON.stringify(param))
    if(ws){
        while(1){
            var ret = ws.read()
            Log("ret:", ret)
            // Respond to heartbeat packet operations
            try {
                var jsonRet = JSON.parse(ret)
                if(typeof(jsonRet.ping) == "number") {
                    var strPong = JSON.stringify({"pong" : jsonRet.ping})
                    ws.write(strPong)
                    Log("Respond to ping, send pong:", strPong, "#FF0000")
                }
            } catch(e) {
                Log("e.name:", e.name, "e.stack:", e.stack, "e.message:", e.message)
            }
            
            LogStatus("Current time:", _D())
            Sleep(1000)
        }
    }
}              

function onexit() {
    ws.close() 
    Log("Execute the ws.close() function")
}
import json
ws = None              

def main():
    global ws
    param = {"sub" : "market.btcusdt.detail", "id" : "id1"}
    ws = Dial("wss://api.huobi.pro/ws|compress=gzip&mode=recv&reconnect=true&payload=" + json.dumps(param))
    if ws:
        while True:
            ret = ws.read()
            Log("ret:", ret)              
            # Respond to heartbeat packet operations
            try:
                jsonRet = json.loads(ret)
                if "ping" in jsonRet and type(jsonRet["ping"]) == int:
                    strPong = json.dumps({"pong" : jsonRet["ping"]})
                    ws.write(strPong)
                    Log("Respond to ping, send pong:", strPong, "#FF0000")
            except Exception as e:
                Log("e:", e)
                
            LogStatus("Current time:", _D())
            Sleep(1000)
    
def onexit():
    ws.close()
    Log("Execute the ws.close() function")  
using namespace std;
void main() {
    json param = R"({"sub" : "market.btcusdt.detail", "id" : "id1"})"_json;
    auto ws = Dial("wss://api.huobi.pro/ws|compress=gzip&mode=recv&reconnect=true&payload=" + param.dump());
    if(ws.Valid) {
        while(true) {
            auto ret = ws.read();
            Log("ret:", ret);              
            // Respond to heartbeat packet operations
            try 
            {
                auto jsonRet = json::parse(ret);
                if(jsonRet["ping"].is_number()) {
                    json pong = R"({"pong" : 0})"_json;
                    pong["pong"] = jsonRet["ping"];
                    auto strPong = pong.dump();
                    ws.write(strPong);
                    Log("Respond to ping, send pong:", strPong, "#FF0000");
                }
            } catch(exception &e) 
            {
                Log("e:", e.what());
            }
            
            LogStatus("Current time:", _D());
            Sleep(1000);
        }
    }
}              

void onexit() {
    // ws.close();
    Log("Execute the ws.close() function");
}

Huobi এর ওয়েবসকেট টিকার ইন্টারফেসে অ্যাক্সেসঃ

function getLogin(pAccessKey, pSecretKey, pPassphrase) {
    // Signature function for login
    var ts = (new Date().getTime() / 1000).toString()
    var login = {
        "op": "login",
        "args":[{
            "apiKey"    : pAccessKey,
            "passphrase" : pPassphrase,
            "timestamp" : ts,
            "sign" : exchange.HMAC("sha256", "base64", ts + "GET" + "/users/self/verify", pSecretKey)   // exchange.HMAC has been deprecated and is temporarily supported. Please use the latest exchange.Encode function instead.
        }]
    }    
    return login
}                

var client_private = null 
function main() {
    // Because the read function uses a timeout setting, filtering the timeout reports errors that would otherwise be output with redundant errors
    SetErrorFilter("timeout")
    
    // Position channel subscription information
    var posSubscribe = {
        "op": "subscribe",
        "args": [{
            "channel": "positions",
            "instType": "ANY"
        }]
    }                

    var accessKey = "xxx"
    var secretKey = "xxx"
    var passphrase = "xxx"            

    client_private = Dial("wss://ws.okx.com:8443/ws/v5/private")
    client_private.write(JSON.stringify(getLogin(accessKey, secretKey, passphrase)))
    Sleep(3000)  // When logging in, you cannot subscribe to private channels immediately, you need to wait for server response
    client_private.write(JSON.stringify(posSubscribe))
    if (client_private) {
        var lastPingTS = new Date().getTime()
        while (true) {
            var buf = client_private.read(-1)
            if (buf) {
                Log(buf)
            }
            
            // Detect disconnection, reconnect
            if (buf == "" && client_private.write(JSON.stringify(posSubscribe)) == 0) {
                Log("Disconnection detected, close connection, reconnect")
                client_private.close()
                client_private = Dial("wss://ws.okx.com:8443/ws/v5/private")
                client_private.write(JSON.stringify(getLogin(accessKey, secretKey, passphrase)))
                Sleep(3000)
                client_private.write(JSON.stringify(posSubscribe))
            }
            
            // Send heartbeat packets
            var nowPingTS = new Date().getTime()
            if (nowPingTS - lastPingTS > 10 * 1000) {
                client_private.write("ping")
                lastPingTS = nowPingTS
            }            
        }        
    }
}                

function onexit() {    
    var ret = client_private.close()
    Log("Close the connection!", ret)
}
import json
import time
  
def getLogin(pAccessKey, pSecretKey, pPassphrase):
    ts = str(time.time())
    login = {
        "op": "login",
        "args":[{
            "apiKey"    : pAccessKey,
            "passphrase" : pPassphrase,
            "timestamp" : ts,
            "sign" : exchange.HMAC("sha256", "base64", ts + "GET" + "/users/self/verify", pSecretKey)
        }]
    }
    return login                 

client_private = None 
def main():
    global client_private
    SetErrorFilter("timeout")
    
    posSubscribe = {
        "op": "subscribe",
        "args": [{
            "channel": "positions",
            "instType": "ANY"
        }]
    }                  

    accessKey = "xxx"
    secretKey = "xxx"
    passphrase = "xxx"
    
    client_private = Dial("wss://ws.okx.com:8443/ws/v5/private")
    client_private.write(json.dumps(getLogin(accessKey, secretKey, passphrase)))
    Sleep(3000)
    client_private.write(json.dumps(posSubscribe))
    if client_private:
        lastPingTS = time.time() * 1000
        while True:
            buf = client_private.read(-1)
            if buf:
                Log(buf)
            
            if buf == "" and client_private.write(json.dumps(posSubscribe)) == 0:
                Log("Disconnection detected, close connection, reconnect")
                ret = client_private.close()
                client_private = Dial("wss://ws.okx.com:8443/ws/v5/private")
                client_private.write(json.dumps(getLogin(accessKey, secretKey, passphrase)))
                Sleep(3000)
                client_private.write(json.dumps(posSubscribe))
            
            nowPingTS = time.time() * 1000
            if nowPingTS - lastPingTS > 10 * 1000:
                client_private.write("ping")
                lastPingTS = nowPingTS                

def onexit():
    ret = client_private.close()
    Log("Close the connection!", ret)
auto client_private = Dial("wss://ws.okx.com:8443/ws/v5/private");                  

json getLogin(string pAccessKey, string pSecretKey, string pPassphrase) {
    auto ts = std::to_string(Unix());
    json login = R"({
        "op": "login",
        "args": [{
            "apiKey": "",
            "passphrase": "",
            "timestamp": "",
            "sign": ""
        }]
    })"_json;
    login["args"][0]["apiKey"] = pAccessKey;
    login["args"][0]["passphrase"] = pPassphrase;
    login["args"][0]["timestamp"] = ts;
    login["args"][0]["sign"] = exchange.HMAC("sha256", "base64", ts + "GET" + "/users/self/verify", pSecretKey);
    return login;
}                  

void main() {
    SetErrorFilter("timeout");
    json posSubscribe = R"({
        "op": "subscribe",
        "args": [{
            "channel": "positions",
            "instType": "ANY"
        }]
    })"_json;
    
    auto accessKey = "xxx";
    auto secretKey = "xxx";
    auto passphrase = "xxx";
    
    client_private.write(getLogin(accessKey, secretKey, passphrase).dump());
    Sleep(3000);
    client_private.write(posSubscribe.dump());                

    if (client_private.Valid) {
        uint64_t lastPingTS = Unix() * 1000;                  

        while (true) {
            auto buf = client_private.read(-1);
            if (buf != "") {
                Log(buf);
            }
            if (buf == "") {
                if (client_private.write(posSubscribe.dump()) == 0) {
                    Log("Disconnection detected, close connection, reconnect");
                    client_private.close();
                    client_private = Dial("wss://ws.okx.com:8443/ws/v5/private");
                    client_private.write(getLogin(accessKey, secretKey, passphrase).dump());
                    Sleep(3000);
                    client_private.write(posSubscribe.dump());
                }
            }
            
            uint64_t nowPingTS = Unix() * 1000;
            if (nowPingTS - lastPingTS > 10 * 1000) {
                client_private.write("ping");
                lastPingTS = nowPingTS;
            }
        }
    }
}                  

void onexit() {
    client_private.close();
    Log("exit");
}

OKX এর ওয়েবসকেট প্রমাণীকরণ ইন্টারফেস অ্যাক্সেস করতেঃ

var client = null 
function main() {
    // client = Dial("sqlite3://:memory:")   // Using an in-memory database
    client = Dial("sqlite3://test1.db")      // Open/connect to the database file in the docker's directory
    
    // record handle
    var sqlite3Handle = client.fd()
    Log("sqlite3Handle:", sqlite3Handle)
    
    // Querying tables in the database
    var ret = client.exec("SELECT name FROM sqlite_master WHERE type='table'")
    Log(ret)
}

function onexit() {
    Log("Execute client.close()")
    client.close()
}
// Not supported
// Not supported

একটি ডাটাবেসের সাথে সংযোগ করার সময় ডায়াল ফাংশন দ্বারা ফেরত দেওয়া সংযোগ অবজেক্টের দুটি পদ্ধতি ফাংশন রয়েছে যা এটির জন্য অনন্যঃ

  • exec(sqlString): এসকিউএল স্ট্র্যাটেজ এক্সিকিউট করার জন্য ব্যবহৃত হয়DBExec() function.
  • fd():fd()ফাংশন একটি হ্যান্ডেল ফেরত দেয় (উদাহরণস্বরূপ, হ্যান্ডেল ভেরিয়েবলটি হ্যান্ডেল) যা অন্য থ্রেডগুলি পুনরায় সংযোগ করতে ব্যবহার করবে (এমনকি যদি ডায়াল দ্বারা তৈরি বস্তুটি ইতিমধ্যে এক্সিকিউশন দ্বারা বন্ধ করা হয়েছেclose()সংযোগ বন্ধ করার জন্য ফাংশন) হ্যান্ডেলটিDial()উদাহরণস্বরূপ,Dial(handle)পুনরায় ব্যবহার সংযোগ. নিম্নলিখিত একটি ডায়াল ফাংশন সংযোগ একটি উদাহরণsqlite3 database.

বিস্তারিতaddressপ্যারামিটার, দ্বারা পৃথক|সাধারণ ঠিকানার পরে চিহ্নঃwss://ws.okx.com:8443/ws/v5/publicযদি থাকে।|পরামিতি স্ট্রিং অক্ষর, তারপর||বিভাজক চিহ্ন হিসাবে ব্যবহার করা হয়. যে পরে অংশ কিছু ফাংশন পরামিতি সেটিংস, এবং প্রতিটি পরামিতি সঙ্গে সংযুক্ত করা হয়&উদাহরণস্বরূপ,ss5প্রক্সি এবং কম্প্রেশন পরামিতিগুলি একসাথে নিম্নরূপ সেট করা যেতে পারেঃDial("wss://ws.okx.com:8443/ws/v5/public|proxy=socks5://xxx:9999&compress=gzip_raw&mode=recv")

ডায়াল ফাংশনের ঠিকানা পরামিতি দ্বারা সমর্থিত ফাংশন প্যারামিটার বর্ণনা
ওয়েবসকেট প্রোটোকলের ডেটা সংকোচনের সাথে সম্পর্কিত পরামিতিঃ কম্প্রেস=প্যারামিটার মান compress হল কম্প্রেশন পদ্ধতি, কম্প্রেস প্যারামিটার অপশন হল: gzip_raw, gzip, ইত্যাদি. যদি gzip পদ্ধতিটি স্ট্যান্ডার্ড gzip না হয়, আপনি বর্ধিত পদ্ধতি ব্যবহার করতে পারেনঃ gzip_raw
ওয়েবসকেট প্রোটোকলের ডেটা সংকোচনের সাথে সম্পর্কিত পরামিতিঃ mode=parameter value মোড হল কম্প্রেশন মোড, মোড প্যারামিটারটি দ্বৈত হতে পারে, পাঠান, recv. দ্বৈত হল দ্বি-মুখী কম্প্রেশন, সংকুচিত ডেটা প্রেরণ করুন, সংকুচিত ডেটা গ্রহণ করুন। প্রেরণ হল সংকুচিত ডেটা প্রেরণ করুন। recv হল সংকুচিত ডেটা গ্রহণ করুন, স্থানীয় ডিকম্প্রেশন।
ওয়েবসকেট প্রোটোকল অন্তর্নিহিত স্বয়ংক্রিয় পুনরায় সংযোগ সম্পর্কিত পরামিতি সেট করেঃ পুনরায় সংযোগ = পরামিতি মান reconnect হল reconnect সেট করতে হবে কিনা, reconnect=true হল reconnect সক্ষম করতে হবে। এই প্যারামিটারটি সেট না হলে ডিফল্ট কোন reconnect হয় না।
ওয়েবসকেট প্রোটোকল অন্তর্নিহিত স্বয়ংক্রিয় পুনরায় সংযোগ সম্পর্কিত পরামিতি সেট করেঃ interval=parameter value interval হল পুনরায় চেষ্টা করার সময়সীমা, মিলিসেকেন্ডে, interval=10000 হল 10 সেকেন্ডের পুনরায় চেষ্টা করার সময়সীমা, ডিফল্টটি 1 সেকেন্ড যখন এটি সেট করা হয় না, অর্থাৎ interval=1000.
ওয়েবসকেট প্রোটোকল অন্তর্নিহিত স্বয়ংক্রিয় পুনরায় সংযোগ সম্পর্কিত পরামিতি সেট করেঃ payload=parameter value payload হল সাবস্ক্রিপশন বার্তা যা WebSocket পুনরায় সংযুক্ত হলে পাঠানো প্রয়োজন, উদাহরণস্বরূপঃ payload=okokok।
Socks5 proxy এর সাথে সম্পর্কিত পরামিতিঃ proxy=প্যারামিটার মান প্রক্সি হল ss5 প্রক্সি সেটিং, প্যারামিটার মান বিন্যাসঃ socks5://name:pwd@192.168.0.1:1080, নাম হচ্ছে এসএস৫ সার্ভারের ইউজার নেম, পিডব্লিউডি হচ্ছে এসএস৫ সার্ভারের লগইন পাসওয়ার্ড, ১০৮০ হচ্ছে এসএস৫ সার্ভিস পোর্ট।

দ্যDial()এই ফাংশনটি শুধুমাত্র লাইভ ট্রেডিং এর জন্য সমর্থিত। ডায়াল ফাংশন ব্যবহার করে একটি ডাটাবেসের সাথে সংযোগ করার সময়, সংযোগ স্ট্রিং প্রতিটি ডাটাবেসের জন্য go ভাষা ড্রাইভার প্রকল্পের উল্লেখ করে লেখা হয়।

সমর্থিত ডাটাবেস চালিকাশক্তি প্রকল্প সংযোগ স্ট্রিং মন্তব্যসমূহ
স্কিলেট3 github.com/mattn/go-sqlite3 sqlite3://file:test.db?cache=shared&mode=memory দ্যsqlite3://প্রিফিক্স নির্দেশ করে যে sqlite3 ডাটাবেস ব্যবহার করা হচ্ছে, উদাহরণ কলঃDial("sqlite3://test1.db")
মাইএসকিউএল github.com/go-sql-driver/mysql mysql://username:yourpassword@tcp(localhost:3306)/আপনার ডাটাবেজ?
পশুপালন github.com/lib/pq postgres://user=postgres dbname=yourdatabase sslmode=disable password=yourpassword হোস্ট=স্থানীয় হোস্ট পোর্ট=5432
ক্লিকহাউস github.com/ClickHouse/clickhouse-go clickhouse://tcp://host:9000?username=username&password=yourpassword&database=youdatabase ব্যবহারকারীর নাম এবং পাসওয়ার্ড

দয়া করে মনে রাখবেন যে যখনpayloadবিষয়বস্তু সেটaddressপ্যারামিটারে অক্ষর রয়েছে=অথবা অন্যান্য বিশেষ অক্ষর, এটা প্যারসিং প্রভাবিত করতে পারেaddressপ্যারামিটারDialফাংশন, যেমন নিম্নলিখিত উদাহরণ।

ব্যাকপ্যাক এক্সচেঞ্জ ওয়েবসকেট ব্যক্তিগত ইন্টারফেস কল উদাহরণঃ

var client = null

function main() {
    // Base64-encoded public key of the key pair, i.e. the access key configured on FMZ
    var base64ApiKey = "xxx"

    var ts = String(new Date().getTime())
    var data = "instruction=subscribe&timestamp=" + ts + "&window=5000"

    // Since signEd25519 returns a base64 encoding, it contains the character "="
    var signature = signEd25519(data)
    
    // The payload may contain the character "=" after being encoded by JSON
    payload = {
        "method": "SUBSCRIBE",
        "params": ["account.orderUpdate"],
        "signature": [base64ApiKey, signature, ts, "5000"]
    }

    client = Dial("wss://ws.backpack.exchange")
    client.write(JSON.stringify(payload))
    if (!client) {
        Log("Connection failed, program exited")
        return
    }
    
    while (true) {
        var buf = client.read()      
        Log(buf)
    }    
}

function onexit() {
    client.close()
}

function signEd25519(data) {
    return exchange.Encode("ed25519.seed", "raw", "base64", data, "base64", "{{secretkey}}")
}

কোডের নিম্নলিখিত কল ঠিকমত কাজ করেঃ

client = Dial("wss://ws.backpack.exchange")
client.write(JSON.stringify(payload))

যদি আপনি এটা সরাসরি লিখেনpayload, এটি সঠিকভাবে কাজ করবে না, উদাহরণস্বরূপঃ

client = Dial("wss://ws.backpack.exchange|payload=" + JSON.stringify(payload))

বর্তমানে, শুধুমাত্র জাভাস্ক্রিপ্ট ব্যবহার সমর্থন করেmqtt, nats, amqp, এবংkafkaডায়াল ফাংশনে যোগাযোগ প্রোটোকল। চারটি প্রোটোকলের ব্যবহার দেখানোর জন্য জাভাস্ক্রিপ্ট ভাষা কৌশল কোড একটি উদাহরণ হিসাবে ব্যবহৃত হয়ঃmqtt, nats, amqp, এবংkafka:

// We need to configure and deploy proxy servers for each protocol first.
// For the sake of demonstration, the subscription (read operation) and publishing (write operation) of the topic test_topic are all performed in the current strategy.
var arrConn = []
var arrName = []

function main() {
    LogReset(1)
    conn_nats = Dial("nats://admin@127.0.0.1:4222?topic=test_topic")
    conn_mqtt = Dial("mqtt://127.0.0.1:1883?topic=test_topic")
    conn_amqp = Dial("amqp://q:admin@127.0.0.1:5672/?queue=test_Queue")
    conn_kafka = Dial("kafka://localhost:9092/test_topic")
    arrConn = [conn_nats, conn_amqp, conn_mqtt, conn_kafka]
    arrName = ["nats", "amqp", "mqtt", "kafka"]

    while (true) {
        for (var i in arrConn) {
            var conn = arrConn[i]
            var name = arrName[i]

            // Write data
            conn.write(name + ", time: " + _D() + ", test msg.")
            
            // Read data
            var readMsg = conn.read(1000)
            Log(name + " readMsg: ", readMsg, "#FF0000")
        }

        Sleep(1000)
    }
}

function onexit() {
    for (var i in arrConn) {
        arrConn[i].close()
        Log("close", arrName[i], "connect")
    }
}

বিস্তারিত ডকুমেন্টেশন রেফারেন্সঃএফএমজেড এক্সপ্লোরিংঃ লাইভ ট্রেডিং কৌশলগুলির মধ্যে যোগাযোগ প্রোটোকলের অনুশীলন

GetMeta HttpQuery