Slack 튜토리얼 - 슬래시 명령어(1세대)


이 튜토리얼에서는 Cloud Run Functions를 사용하여 Google Knowledge Graph API를 검색하는 Slack 슬래시 명령어의 구현 방법을 설명합니다.

목표

  • Slack에서 슬래시 명령어를 만듭니다.
  • HTTP Cloud Run 함수를 작성하고 배포합니다.
  • 슬래시 명령어를 사용하여 Google Knowledge Graph API를 검색합니다.

비용

이 문서에서는 비용이 청구될 수 있는 Google Cloud구성요소( )를 사용합니다.

  • Cloud Run functions

프로젝트 사용량을 기준으로 예상 비용을 산출하려면 가격 계산기를 사용합니다.

Google Cloud 신규 사용자는 무료 체험판을 사용할 수 있습니다.

시작하기 전에

  1. Sign in to your Google Cloud account. If you're new to Google Cloud, create an account to evaluate how our products perform in real-world scenarios. New customers also get $300 in free credits to run, test, and deploy workloads.
  2. In the Google Cloud console, on the project selector page, select or create a Google Cloud project.

    Go to project selector

  3. Verify that billing is enabled for your Google Cloud project.

  4. Enable the Cloud Functions, Cloud Build, and Google Knowledge Graph Search APIs.

    Enable the APIs

  5. Install the Google Cloud CLI.

  6. 외부 ID 공급업체(IdP)를 사용하는 경우 먼저 제휴 ID로 gcloud CLI에 로그인해야 합니다.

  7. gcloud CLI를 초기화하려면, 다음 명령어를 실행합니다.

    gcloud init
  8. In the Google Cloud console, on the project selector page, select or create a Google Cloud project.

    Go to project selector

  9. Verify that billing is enabled for your Google Cloud project.

  10. Enable the Cloud Functions, Cloud Build, and Google Knowledge Graph Search APIs.

    Enable the APIs

  11. Install the Google Cloud CLI.

  12. 외부 ID 공급업체(IdP)를 사용하는 경우 먼저 제휴 ID로 gcloud CLI에 로그인해야 합니다.

  13. gcloud CLI를 초기화하려면, 다음 명령어를 실행합니다.

    gcloud init
  14. gcloud CLI가 이미 설치되어 있으면 다음 명령어를 실행하여 업데이트합니다.

    gcloud components update
  15. 개발 환경을 준비합니다.
  16. 데이터 흐름 시각화

    Slack 슬래시 명령어 튜토리얼 애플리케이션의 데이터 흐름 단계는 다음과 같습니다.

    1. 사용자가 Slack 채널에서 /kg <search_query> 슬래시 명령어를 실행합니다.
    2. Slack은 명령어 페이로드를 함수의 트리거 엔드포인트로 보냅니다.
    3. 함수는 사용자의 검색어와 함께 Knowledge Graph API에 요청을 보냅니다.
    4. Knowledge Graph API는 이와 일치하는 결과로 응답합니다.
    5. 함수는 응답의 형식을 Slack 메시지로 지정합니다.
    6. 함수는 메시지를 다시 Slack으로 보냅니다.
    7. 사용자는 Slack 채널에서 형식 지정된 응답을 봅니다.

    해당 단계를 시각화하면 다음과 같습니다.

    Knowledge Graph API 키 만들기

    Google Cloud 콘솔 사용자 인증 정보 페이지에서 사용자 인증 정보 만들기 버튼을 클릭하고 API 키를 선택합니다. 이 키를 사용하여 다음 섹션에서 Knowledge Graph API에 액세스합니다.

    함수 준비

    1. 샘플 앱 저장소를 로컬 머신에 클론합니다.

      Node.js

      git clone https://github.com/GoogleCloudPlatform/nodejs-docs-samples.git

      또는 zip 파일로 샘플을 다운로드하고 압축을 풀 수 있습니다.

      Python

      git clone https://github.com/GoogleCloudPlatform/python-docs-samples.git

      또는 zip 파일로 샘플을 다운로드하고 압축을 풀 수 있습니다.

      Go

      git clone https://github.com/GoogleCloudPlatform/golang-samples.git

      또는 zip 파일로 샘플을 다운로드하고 압축을 풀 수 있습니다.

      자바

      git clone https://github.com/GoogleCloudPlatform/java-docs-samples.git

      또는 zip 파일로 샘플을 다운로드하고 압축을 풀 수 있습니다.

      Ruby

      git clone https://github.com/GoogleCloudPlatform/ruby-docs-samples.git

      또는 zip 파일로 샘플을 다운로드하고 압축을 풀 수 있습니다.

    2. Cloud Run Functions 샘플 코드가 포함된 디렉터리로 변경합니다.

      Node.js

      cd nodejs-docs-samples/functions/slack/

      Python

      cd python-docs-samples/functions/slack/

      Go

      cd golang-samples/functions/slack/

      자바

      cd java-docs-samples/functions/slack/

      Ruby

      cd ruby-docs-samples/functions/slack/

    함수 배포

    사용자 또는 Slack이 함수의 엔드포인트에 HTTP POST 요청을 실행할 때 실행되는 함수를 배포하려면 샘플 코드(또는 자바용 pom.xml 파일)를 포함하는 디렉터리에서 다음 명령어를 실행합니다.

    YOUR_SLACK_SIGNING_SECRET을 앱 구성의 기본 정보 페이지에서 Slack이 제공한 서명 보안 비밀로, YOUR_KG_API_KEY를 앞에서 만든 Knowledge Graph API 키로 바꿉니다.

    Node.js

    gcloud functions deploy kgSearch \
    --runtime nodejs20 \
    --trigger-http \
    --set-env-vars "SLACK_SECRET=YOUR_SLACK_SIGNING_SECRET,KG_API_KEY=YOUR_KG_API_KEY" \
    --allow-unauthenticated

    --runtime 플래그를 사용하여 함수를 실행할 지원되는 Node.js 버전의 런타임 ID를 지정합니다.

    Python

    gcloud functions deploy kg_search \
    --runtime python312 \
    --trigger-http \
    --set-env-vars "SLACK_SECRET=YOUR_SLACK_SIGNING_SECRET,KG_API_KEY=YOUR_KG_API_KEY" \
    --allow-unauthenticated

    --runtime 플래그를 사용하여 함수를 실행할 지원되는 Python 버전의 런타임 ID를 지정합니다.

    Go

    gcloud functions deploy KGSearch \
    --runtime go121 \
    --trigger-http \
    --set-env-vars "SLACK_SECRET=YOUR_SLACK_SIGNING_SECRET,KG_API_KEY=YOUR_KG_API_KEY" \
    --allow-unauthenticated

    --runtime 플래그를 사용하여 함수를 실행할 지원되는 Go 버전의 런타임 ID를 지정합니다.

    자바

    gcloud functions deploy java-slack-function \
    --entry-point functions.SlackSlashCommand \
    --runtime java17 \
    --memory 512MB \
    --trigger-http \
    --set-env-vars "SLACK_SECRET=YOUR_SLACK_SIGNING_SECRET,KG_API_KEY=YOUR_KG_API_KEY" \
    --allow-unauthenticated

    --runtime 플래그를 사용하여 함수를 실행할 지원되는 Java 버전의 런타임 ID를 지정합니다.

    Ruby

    gcloud functions deploy kg_search --runtime ruby33 \
    -
    -trigger-http \
    -
    -set-env-vars "SLACK_SECRET=YOUR_SLACK_SIGNING_SECRET,KG_API_KEY=YOUR_KG_API_KEY" \
    -
    -allow-unauthenticated

    --runtime 플래그를 사용하여 함수를 실행할 지원되는 Ruby 버전의 런타임 ID를 지정합니다.

    애플리케이션 구성

    함수가 배포되면 명령어가 트리거될 때마다 함수에 쿼리를 보내는 Slack 슬래시 명령어를 생성해야 합니다.

    1. Slack 슬래시 명령어를 호스트할 Slack 앱을 만듭니다. 이를 통합 설치 권한이 있는 Slack팀과 연결합니다.

    2. 슬래시 명령어로 이동하여 새로운 명령어 만들기 버튼을 클릭합니다.

    3. /kg를 명령어 이름으로 입력합니다.

    4. 명령어의 URL을 입력합니다.

      Node.js

      https://YOUR_REGION-YOUR_PROJECT_ID.cloudfunctions.net/kgSearch

      Python

      https://YOUR_REGION-YOUR_PROJECT_ID.cloudfunctions.net/kg_search

      Go

      https://YOUR_REGION-YOUR_PROJECT_ID.cloudfunctions.net/KGSearch

      자바

      https://YOUR_REGION-YOUR_PROJECT_ID.cloudfunctions.net/java-slack-function

      Ruby

      https://YOUR_REGION-YOUR_PROJECT_ID.cloudfunctions.net/kg_search

      여기서 YOUR_REGION은 함수가 배포된 리전이고 YOUR_PROJECT_ID는 Cloud 프로젝트 ID입니다.

      함수 배포가 끝나면 두 값 모두 터미널에 표시됩니다.

    5. 저장을 클릭합니다.

    6. 기본 정보로 이동합니다.

    7. 작업공간에 앱 설치를 클릭하고 화면의 안내에 따라 작업공간에 애플리케이션을 사용 설정합니다.

      Slack 슬래시 명령어가 곧 작동됩니다.

    코드 이해하기

    종속 항목 가져오기

    애플리케이션은 Google Cloud Platform 서비스와 통신하기 위해 몇 가지 종속성을 가져와야 합니다.

    Node.js

    const functions = require('@google-cloud/functions-framework');
    const google = require('@googleapis/kgsearch');
    const {verifyRequestSignature} = require('@slack/events-api');
    
    // Get a reference to the Knowledge Graph Search component
    const kgsearch = google.kgsearch('v1');

    Python

    import os
    
    from flask import jsonify
    import functions_framework
    import googleapiclient.discovery
    from slack.signature import SignatureVerifier
    
    
    kgsearch = googleapiclient.discovery.build(
        "kgsearch", "v1", developerKey=os.environ["KG_API_KEY"], cache_discovery=False
    )

    Go

    
    package slack
    
    import (
    	"context"
    	"log"
    	"os"
    
    	"google.golang.org/api/kgsearch/v1"
    	"google.golang.org/api/option"
    )
    
    var (
    	entitiesService *kgsearch.EntitiesService
    	kgKey           string
    	slackSecret     string
    )
    
    func setup(ctx context.Context) {
    	kgKey = os.Getenv("KG_API_KEY")
    	slackSecret = os.Getenv("SLACK_SECRET")
    
    	if entitiesService == nil {
    		kgService, err := kgsearch.NewService(ctx, option.WithAPIKey(kgKey))
    		if err != nil {
    			log.Fatalf("kgsearch.NewService: %v", err)
    		}
    		entitiesService = kgsearch.NewEntitiesService(kgService)
    	}
    }
    

    자바

    private static final Logger logger = Logger.getLogger(SlackSlashCommand.class.getName());
    private static final String API_KEY = getenv("KG_API_KEY");
    private static final String SLACK_SECRET = getenv("SLACK_SECRET");
    private static final Gson gson = new Gson();
    
    private final String apiKey;
    private final Kgsearch kgClient;
    private final SlackSignature.Verifier verifier;
    
    public SlackSlashCommand() throws IOException, GeneralSecurityException {
      this(new SlackSignature.Verifier(new SlackSignature.Generator(SLACK_SECRET)));
    }
    
    SlackSlashCommand(SlackSignature.Verifier verifier) throws IOException, GeneralSecurityException {
      this(verifier, API_KEY);
    }
    
    SlackSlashCommand(SlackSignature.Verifier verifier, String apiKey)
        throws IOException, GeneralSecurityException {
      this.verifier = verifier;
      this.apiKey = apiKey;
      this.kgClient = new Kgsearch.Builder(
          GoogleNetHttpTransport.newTrustedTransport(), new GsonFactory(), null).build();
    }
    
    // Avoid ungraceful deployment failures due to unset environment variables.
    // If you get this warning you should redeploy with the variable set.
    private static String getenv(String name) {
      String value = System.getenv(name);
      if (value == null) {
        logger.warning("Environment variable " + name + " was not set");
        value = "MISSING";
      }
      return value;
    }

    Ruby

    require "functions_framework"
    require "slack-ruby-client"
    require "google/apis/kgsearch_v1"
    
    # This block is executed during cold start, before the function begins
    # handling requests. This is the recommended way to create shared resources
    # and objects.
    FunctionsFramework.on_startup do
      # Create a global handler object, configured with the environment-provided
      # API key and signing secret.
      kg_search = KGSearch.new kg_api_key:     ENV["KG_API_KEY"],
                               signing_secret: ENV["SLACK_SECRET"]
      set_global :kg_search, kg_search
    end
    
    # The KGSearch class implements the logic of validating and responding
    # to requests. More methods of this class are shown below.
    class KGSearch
      def initialize kg_api_key:, signing_secret:
        # Create the global client for the Knowledge Graph Search Service,
        # configuring it with your API key.
        @client = Google::Apis::KgsearchV1::KgsearchService.new
        @client.key = kg_api_key
    
        # Save signing secret for use by the signature validation method.
        @signing_secret = signing_secret
      end

    웹훅 수신

    다음 함수는 사용자(또는 Slack)가 함수의 엔드포인트로 HTTP POST 요청을 보낼 때 실행됩니다.

    Node.js

    /**
     * Receive a Slash Command request from Slack.
     *
     * Trigger this function by creating a Slack slash command with the HTTP Trigger URL.
     * You can find the HTTP URL in the Cloud Console or using `gcloud functions describe`
     *
     * @param {object} req Cloud Function request object.
     * @param {object} req.body The request payload.
     * @param {string} req.rawBody Raw request payload used to validate Slack's message signature.
     * @param {string} req.body.text The user's search query.
     * @param {object} res Cloud Function response object.
     */
    functions.http('kgSearch', async (req, res) => {
      try {
        if (req.method !== 'POST') {
          const error = new Error('Only POST requests are accepted');
          error.code = 405;
          throw error;
        }
    
        if (!req.body.text) {
          const error = new Error('No text found in body.');
          error.code = 400;
          throw error;
        }
    
        // Verify that this request came from Slack
        verifyWebhook(req);
    
        // Make the request to the Knowledge Graph Search API
        const response = await makeSearchRequest(req.body.text);
    
        // Send the formatted message back to Slack
        res.json(response);
    
        return Promise.resolve();
      } catch (err) {
        console.error(err);
        res.status(err.code || 500).send(err);
        return Promise.reject(err);
      }
    });

    Python

    @functions_framework.http
    def kg_search(request):
        if request.method != "POST":
            return "Only POST requests are accepted", 405
    
        verify_signature(request)
        kg_search_response = make_search_request(request.form["text"])
        return jsonify(kg_search_response)
    
    

    Go

    
    // Package slack is a Cloud Function which recieves a query from
    // a Slack command and responds with the KG API result.
    package slack
    
    import (
    	"bytes"
    	"crypto/hmac"
    	"crypto/sha256"
    	"encoding/hex"
    	"encoding/json"
    	"fmt"
    	"io"
    	"log"
    	"net/http"
    	"strconv"
    	"strings"
    	"time"
    )
    
    type oldTimeStampError struct {
    	s string
    }
    
    func (e *oldTimeStampError) Error() string {
    	return e.s
    }
    
    const (
    	version                     = "v0"
    	slackRequestTimestampHeader = "X-Slack-Request-Timestamp"
    	slackSignatureHeader        = "X-Slack-Signature"
    )
    
    type attachment struct {
    	Color     string `json:"color"`
    	Title     string `json:"title"`
    	TitleLink string `json:"title_link"`
    	Text      string `json:"text"`
    	ImageURL  string `json:"image_url"`
    }
    
    // Message is the a Slack message event.
    // see https://api.slack.com/docs/message-formatting
    type Message struct {
    	ResponseType string       `json:"response_type"`
    	Text         string       `json:"text"`
    	Attachments  []attachment `json:"attachments"`
    }
    
    // KGSearch uses the Knowledge Graph API to search for a query provided
    // by a Slack command.
    func KGSearch(w http.ResponseWriter, r *http.Request) {
    	setup(r.Context())
    
    	bodyBytes, err := io.ReadAll(r.Body)
    	if err != nil {
    		log.Fatalf("Couldn't read request body: %v", err)
    	}
    	r.Body = io.NopCloser(bytes.NewBuffer(bodyBytes))
    
    	if r.Method != "POST" {
    		http.Error(w, "Only POST requests are accepted", http.StatusMethodNotAllowed)
    	}
    	if err := r.ParseForm(); err != nil {
    		http.Error(w, "Couldn't parse form", 400)
    		log.Fatalf("ParseForm: %v", err)
    	}
    
    	// Reset r.Body as ParseForm depletes it by reading the io.ReadCloser.
    	r.Body = io.NopCloser(bytes.NewBuffer(bodyBytes))
    	result, err := verifyWebHook(r, slackSecret)
    	if err != nil {
    		log.Fatalf("verifyWebhook: %v", err)
    	}
    	if !result {
    		log.Fatalf("signatures did not match.")
    	}
    
    	if len(r.Form["text"]) == 0 {
    		log.Fatalf("empty text in form")
    	}
    	kgSearchResponse, err := makeSearchRequest(r.Form["text"][0])
    	if err != nil {
    		log.Fatalf("makeSearchRequest: %v", err)
    	}
    	w.Header().Set("Content-Type", "application/json")
    	if err = json.NewEncoder(w).Encode(kgSearchResponse); err != nil {
    		log.Fatalf("json.Marshal: %v", err)
    	}
    }
    

    자바

    /**
     * Receive a Slash Command request from Slack.
     *
     * @param request Cloud Function request object.
     * @param response Cloud Function response object.
     * @throws IOException if Knowledge Graph request fails
     */
    @Override
    public void service(HttpRequest request, HttpResponse response) throws IOException {
    
      // Validate request
      if (!"POST".equals(request.getMethod())) {
        response.setStatusCode(HttpURLConnection.HTTP_BAD_METHOD);
        return;
      }
    
      // reader can only be read once per request, so we preserve its contents
      String bodyString = request.getReader().lines().collect(Collectors.joining());
    
      // Slack sends requests as URL-encoded strings
      //   Java 11 doesn't have a standard library
      //   function for this, so do it manually
      Map<String, String> body = new HashMap<>();
      for (String keyValuePair : bodyString.split("&")) {
        String[] keyAndValue = keyValuePair.split("=");
        if (keyAndValue.length == 2) {
          String key = keyAndValue[0];
          String value = keyAndValue[1];
    
          body.put(key, value);
        }
      }
    
      if (body == null || !body.containsKey("text")) {
        response.setStatusCode(HttpURLConnection.HTTP_BAD_REQUEST);
        return;
      }
    
      if (!isValidSlackWebhook(request, bodyString)) {
        response.setStatusCode(HttpURLConnection.HTTP_UNAUTHORIZED);
        return;
      }
    
      String query = body.get("text");
    
      // Call knowledge graph API
      JsonObject kgResponse = searchKnowledgeGraph(query);
    
      // Format response to Slack
      // See https://api.slack.com/docs/message-formatting
      BufferedWriter writer = response.getWriter();
    
      writer.write(formatSlackMessage(kgResponse, query));
    
      response.setContentType("application/json");
    }

    Ruby

    # Handler for the function endpoint.
    FunctionsFramework.http "kg_search" do |request|
      # Return early if the request is not a POST.
      unless request.post?
        return [405, {}, ["Only POST requests are accepted."]]
      end
    
      # Access the global Knowledge Graph Search client
      kg_search = global :kg_search
    
      # Verify the request signature and return early if it failed.
      unless kg_search.signature_valid? request
        return [401, {}, ["Signature validation failed."]]
      end
    
      # Query the Knowledge Graph and format a Slack message with the response.
      # This method returns a nested hash, which the Functions Framework will
      # convert to JSON automatically.
      kg_search.make_search_request request.params["text"]
    end

    다음 함수는 Slack이 제공한 X-Slack-Signature 헤더를 확인하여 들어오는 요청을 인증합니다.

    Node.js

    /**
     * Verify that the webhook request came from Slack.
     *
     * @param {object} req Cloud Function request object.
     * @param {string} req.headers Headers Slack SDK uses to authenticate request.
     * @param {string} req.rawBody Raw body of webhook request to check signature against.
     */
    const verifyWebhook = req => {
      const signature = {
        signingSecret: process.env.SLACK_SECRET,
        requestSignature: req.headers['x-slack-signature'],
        requestTimestamp: req.headers['x-slack-request-timestamp'],
        body: req.rawBody,
      };
    
      // This method throws an exception if an incoming request is invalid.
      verifyRequestSignature(signature);
    };

    Python

    def verify_signature(request):
        request.get_data()  # Decodes received requests into request.data
    
        verifier = SignatureVerifier(os.environ["SLACK_SECRET"])
    
        if not verifier.is_valid_request(request.data, request.headers):
            raise ValueError("Invalid request/credentials.")
    
    

    Go

    
    // verifyWebHook verifies the request signature.
    // See https://api.slack.com/docs/verifying-requests-from-slack.
    func verifyWebHook(r *http.Request, slackSigningSecret string) (bool, error) {
    	timeStamp := r.Header.Get(slackRequestTimestampHeader)
    	slackSignature := r.Header.Get(slackSignatureHeader)
    
    	t, err := strconv.ParseInt(timeStamp, 10, 64)
    	if err != nil {
    		return false, fmt.Errorf("strconv.ParseInt(%s): %w", timeStamp, err)
    	}
    
    	if ageOk, age := checkTimestamp(t); !ageOk {
    		return false, &oldTimeStampError{fmt.Sprintf("checkTimestamp(%v): %v %v", t, ageOk, age)}
    		// return false, fmt.Errorf("checkTimestamp(%v): %v %v", t, ageOk, age)
    	}
    
    	if timeStamp == "" || slackSignature == "" {
    		return false, fmt.Errorf("either timeStamp or signature headers were blank")
    	}
    
    	body, err := io.ReadAll(r.Body)
    	if err != nil {
    		return false, fmt.Errorf("io.ReadAll(%v): %w", r.Body, err)
    	}
    
    	// Reset the body so other calls won't fail.
    	r.Body = io.NopCloser(bytes.NewBuffer(body))
    
    	baseString := fmt.Sprintf("%s:%s:%s", version, timeStamp, body)
    
    	signature := getSignature([]byte(baseString), []byte(slackSigningSecret))
    
    	trimmed := strings.TrimPrefix(slackSignature, fmt.Sprintf("%s=", version))
    	signatureInHeader, err := hex.DecodeString(trimmed)
    
    	if err != nil {
    		return false, fmt.Errorf("hex.DecodeString(%v): %w", trimmed, err)
    	}
    
    	return hmac.Equal(signature, signatureInHeader), nil
    }
    
    func getSignature(base []byte, secret []byte) []byte {
    	h := hmac.New(sha256.New, secret)
    	h.Write(base)
    
    	return h.Sum(nil)
    }
    
    // Arbitrarily trusting requests time stamped less than 5 minutes ago.
    func checkTimestamp(timeStamp int64) (bool, time.Duration) {
    	t := time.Since(time.Unix(timeStamp, 0))
    
    	return t.Minutes() <= 5, t
    }
    

    자바

    /**
     * Verify that the webhook request came from Slack.
     *
     * @param request Cloud Function request object in {@link HttpRequest} format.
     * @param requestBody Raw body of webhook request to check signature against.
     * @return true if the provided request came from Slack, false otherwise
     */
    boolean isValidSlackWebhook(HttpRequest request, String requestBody) {
      // Check for headers
      Optional<String> maybeTimestamp = request.getFirstHeader("X-Slack-Request-Timestamp");
      Optional<String> maybeSignature = request.getFirstHeader("X-Slack-Signature");
      if (!maybeTimestamp.isPresent() || !maybeSignature.isPresent()) {
        return false;
      }
    
      Long nowInMs = ZonedDateTime.now().toInstant().toEpochMilli();
    
      return verifier.isValid(maybeTimestamp.get(), requestBody, maybeSignature.get(), nowInMs);
    }

    Ruby

    # slack-ruby-client expects a Rails-style request object with a "headers"
    # method, but the Functions Framework provides only a Rack request.
    # To avoid bringing in Rails as a dependency, we'll create a simple class
    # that implements the "headers" method and delegates everything else back to
    # the Rack request object.
    require "delegate"
    class RequestWithHeaders < SimpleDelegator
      def headers
        env.each_with_object({}) do |(key, val), result|
          if /^HTTP_(\w+)$/ =~ key
            header = Regexp.last_match(1).split("_").map(&:capitalize).join("-")
            result[header] = val
          end
        end
      end
    end
    
    # This is a method of the KGSearch class.
    # It determines whether the given request's signature is valid.
    def signature_valid? request
      # Wrap the request with our class that provides the "headers" method.
      request = RequestWithHeaders.new request
    
      # Validate the request signature.
      slack_request = Slack::Events::Request.new request,
                                                 signing_secret: @signing_secret
      slack_request.valid?
    end

    Knowledge Graph API 쿼리

    다음 함수는 사용자의 검색어와 함께 Knowledge Graph API에 요청을 보냅니다.

    Node.js

    /**
     * Send the user's search query to the Knowledge Graph API.
     *
     * @param {string} query The user's search query.
     */
    const makeSearchRequest = query => {
      return new Promise((resolve, reject) => {
        kgsearch.entities.search(
          {
            auth: process.env.KG_API_KEY,
            query: query,
            limit: 1,
          },
          (err, response) => {
            console.log(err);
            if (err) {
              reject(err);
              return;
            }
    
            // Return a formatted message
            resolve(formatSlackMessage(query, response));
          }
        );
      });
    };

    Python

    def make_search_request(query):
        req = kgsearch.entities().search(query=query, limit=1)
        res = req.execute()
        return format_slack_message(query, res)
    
    

    Go

    func makeSearchRequest(query string) (*Message, error) {
    	res, err := entitiesService.Search().Query(query).Limit(1).Do()
    	if err != nil {
    		return nil, fmt.Errorf("do: %w", err)
    	}
    	return formatSlackMessage(query, res)
    }
    

    자바

    /**
     * Send the user's search query to the Knowledge Graph API.
     *
     * @param query The user's search query.
     * @return The Knowledge graph API results as a {@link JsonObject}.
     * @throws IOException if Knowledge Graph request fails
     */
    JsonObject searchKnowledgeGraph(String query) throws IOException {
      Kgsearch.Entities.Search kgRequest = kgClient.entities().search();
      kgRequest.setQuery(query);
      kgRequest.setKey(apiKey);
    
      return gson.fromJson(kgRequest.execute().toString(), JsonObject.class);
    }

    Ruby

    # This is a method of the KGSearch class.
    # It makes an API call to the Knowledge Graph Search Service, and formats
    # a Slack message as a nested Hash object.
    def make_search_request query
      response = @client.search_entities query: query, limit: 1
      format_slack_message query, response
    end

    Slack 메시지 형식 지정

    마지막으로 다음 함수는 지식 정보 결과를 서식 있는 Slack 메시지로 형식 지정하여 사용자에게 표시합니다.

    Node.js

    /**
     * Format the Knowledge Graph API response into a richly formatted Slack message.
     *
     * @param {string} query The user's search query.
     * @param {object} response The response from the Knowledge Graph API.
     * @returns {object} The formatted message.
     */
    const formatSlackMessage = (query, response) => {
      let entity;
    
      // Extract the first entity from the result list, if any
      if (
        response &&
        response.data &&
        response.data.itemListElement &&
        response.data.itemListElement.length > 0
      ) {
        entity = response.data.itemListElement[0].result;
      }
    
      // Prepare a rich Slack message
      // See https://api.slack.com/docs/message-formatting
      const slackMessage = {
        response_type: 'in_channel',
        text: `Query: ${query}`,
        attachments: [],
      };
    
      if (entity) {
        const attachment = {
          color: '#3367d6',
        };
        if (entity.name) {
          attachment.title = entity.name;
          if (entity.description) {
            attachment.title = `${attachment.title}: ${entity.description}`;
          }
        }
        if (entity.detailedDescription) {
          if (entity.detailedDescription.url) {
            attachment.title_link = entity.detailedDescription.url;
          }
          if (entity.detailedDescription.articleBody) {
            attachment.text = entity.detailedDescription.articleBody;
          }
        }
        if (entity.image && entity.image.contentUrl) {
          attachment.image_url = entity.image.contentUrl;
        }
        slackMessage.attachments.push(attachment);
      } else {
        slackMessage.attachments.push({
          text: 'No results match your query...',
        });
      }
    
      return slackMessage;
    };

    Python

    def format_slack_message(query, response):
        entity = None
        if (
            response
            and response.get("itemListElement") is not None
            and len(response["itemListElement"]) > 0
        ):
            entity = response["itemListElement"][0]["result"]
    
        message = {
            "response_type": "in_channel",
            "text": f"Query: {query}",
            "attachments": [],
        }
    
        attachment = {}
        if entity:
            name = entity.get("name", "")
            description = entity.get("description", "")
            detailed_desc = entity.get("detailedDescription", {})
            url = detailed_desc.get("url")
            article = detailed_desc.get("articleBody")
            image_url = entity.get("image", {}).get("contentUrl")
    
            attachment["color"] = "#3367d6"
            if name and description:
                attachment["title"] = "{}: {}".format(entity["name"], entity["description"])
            elif name:
                attachment["title"] = name
            if url:
                attachment["title_link"] = url
            if article:
                attachment["text"] = article
            if image_url:
                attachment["image_url"] = image_url
        else:
            attachment["text"] = "No results match your query."
        message["attachments"].append(attachment)
    
        return message
    
    

    Go

    
    package slack
    
    import (
    	"fmt"
    
    	"google.golang.org/api/kgsearch/v1"
    )
    
    func formatSlackMessage(query string, response *kgsearch.SearchResponse) (*Message, error) {
    	if response == nil {
    		return nil, fmt.Errorf("empty response")
    	}
    
    	if response.ItemListElement == nil || len(response.ItemListElement) == 0 {
    		message := &Message{
    			ResponseType: "in_channel",
    			Text:         fmt.Sprintf("Query: %s", query),
    			Attachments: []attachment{
    				{
    					Color: "#d6334b",
    					Text:  "No results match your query.",
    				},
    			},
    		}
    		return message, nil
    	}
    
    	entity, ok := response.ItemListElement[0].(map[string]interface{})
    	if !ok {
    		return nil, fmt.Errorf("could not parse response entity")
    	}
    	result, ok := entity["result"].(map[string]interface{})
    	if !ok {
    		return nil, fmt.Errorf("error formatting response result")
    	}
    
    	attach := attachment{Color: "#3367d6"}
    	if name, ok := result["name"].(string); ok {
    		if description, ok := result["description"].(string); ok {
    			attach.Title = fmt.Sprintf("%s: %s", name, description)
    		} else {
    			attach.Title = name
    		}
    	}
    	if detailedDesc, ok := result["detailedDescription"].(map[string]interface{}); ok {
    		if url, ok := detailedDesc["url"].(string); ok {
    			attach.TitleLink = url
    		}
    		if article, ok := detailedDesc["articleBody"].(string); ok {
    			attach.Text = article
    		}
    	}
    	if image, ok := result["image"].(map[string]interface{}); ok {
    		if imageURL, ok := image["contentUrl"].(string); ok {
    			attach.ImageURL = imageURL
    		}
    	}
    
    	message := &Message{
    		ResponseType: "in_channel",
    		Text:         fmt.Sprintf("Query: %s", query),
    		Attachments:  []attachment{attach},
    	}
    	return message, nil
    }
    

    자바

    /**
     * Helper method to copy properties between {@link JsonObject}s
     */
    void addPropertyIfPresent(
        JsonObject target, String targetName, JsonObject source, String sourceName) {
      if (source.has(sourceName)) {
        target.addProperty(targetName, source.get(sourceName).getAsString());
      }
    }
    
    /**
     * Format the Knowledge Graph API response into a richly formatted Slack message.
     *
     * @param kgResponse The response from the Knowledge Graph API as a {@link JsonObject}.
     * @param query The user's search query.
     * @return The formatted Slack message as a JSON string.
     */
    String formatSlackMessage(JsonObject kgResponse, String query) {
      JsonObject attachmentJson = new JsonObject();
    
      JsonObject responseJson = new JsonObject();
      responseJson.addProperty("response_type", "in_channel");
      responseJson.addProperty("text", String.format("Query: %s", query));
    
      JsonArray entityList = kgResponse.getAsJsonArray("itemListElement");
    
      // Extract the first entity from the result list, if any
      if (entityList.size() == 0) {
        attachmentJson.addProperty("text", "No results match your query...");
        responseJson.add("attachments", attachmentJson);
    
        return gson.toJson(responseJson);
      }
    
      JsonObject entity = entityList.get(0).getAsJsonObject().getAsJsonObject("result");
    
      // Construct Knowledge Graph response attachment
      String title = entity.get("name").getAsString();
      if (entity.has("description")) {
        title = String.format("%s: %s", title, entity.get("description").getAsString());
      }
      attachmentJson.addProperty("title", title);
    
      if (entity.has("detailedDescription")) {
        JsonObject detailedDescJson = entity.getAsJsonObject("detailedDescription");
        addPropertyIfPresent(attachmentJson, "title_link", detailedDescJson, "url");
        addPropertyIfPresent(attachmentJson, "text", detailedDescJson, "articleBody");
      }
    
      if (entity.has("image")) {
        JsonObject imageJson = entity.getAsJsonObject("image");
        addPropertyIfPresent(attachmentJson, "image_url", imageJson, "contentUrl");
      }
    
      JsonArray attachmentList = new JsonArray();
      attachmentList.add(attachmentJson);
    
      responseJson.add("attachments", attachmentList);
    
      return gson.toJson(responseJson);
    }

    Ruby

    # This is a method of the KGSearch class.
    # It takes a raw SearchResponse from the Knowledge Graph Search Service,
    # and formats a Slack message.
    def format_slack_message query, response
      result = response.item_list_element&.first&.fetch "result", nil
      attachment =
        if result
          name = result.fetch "name", nil
          description = result.fetch "description", nil
          details = result.fetch "detailedDescription", {}
          { "title"      => name && description ? "#{name}: #{description}" : name,
            "title_link" => details.fetch("url", nil),
            "text"       => details.fetch("articleBody", nil),
            "image_url"  => result.fetch("image", nil)&.fetch("contentUrl", nil) }
        else
          { "text" => "No results match your query." }
        end
      { "response_type" => "in_channel",
        "text"          => "Query: #{query}",
        "attachments"   => [attachment.compact] }
    end

    Slack API 제한 시간

    Slack API는 함수가 웹훅 요청 수신 후 3초 이내에 응답할 것으로 예상합니다.

    이 튜토리얼의 명령어는 일반적으로 3초 이내에 응답합니다. 실행 시간이 더 긴 명령어의 경우 태스크 큐 역할을 하는 Pub/Sub 주제에 요청을 푸시(response_url 포함)하도록 함수를 구성하는 것이 좋습니다.

    그런 다음 Pub/Sub로 트리거되는 두 번째 함수를 만들어 작업을 처리하고 결과를 Slack의 response_url로 다시 보낼 수 있습니다.

    슬래시 명령어 사용

    1. Slack 채널에 다음 명령어를 입력합니다.

      /kg giraffe
    2. 로그를 확인하여 실행이 완료되었는지 확인합니다.

      gcloud functions logs read --limit 100

    삭제

    이 튜토리얼에서 사용된 리소스 비용이 Google Cloud 계정에 청구되지 않도록 하려면 리소스가 포함된 프로젝트를 삭제하거나 프로젝트를 유지하고 개별 리소스를 삭제하세요.

    프로젝트 삭제

    비용이 청구되지 않도록 하는 가장 쉬운 방법은 튜토리얼에서 만든 프로젝트를 삭제하는 것입니다.

    프로젝트를 삭제하는 방법은 다음과 같습니다.

    1. In the Google Cloud console, go to the Manage resources page.

      Go to Manage resources

    2. In the project list, select the project that you want to delete, and then click Delete.
    3. In the dialog, type the project ID, and then click Shut down to delete the project.

    함수 삭제

    이 튜토리얼에서 배포한 함수를 삭제하려면 다음 명령어를 실행합니다.

    Node.js

    gcloud functions delete kgSearch 

    Python

    gcloud functions delete kg_search 

    Go

    gcloud functions delete KGSearch 

    자바

    gcloud functions delete java-slack-function 

    Ruby

    gcloud functions delete kg_search 

    또한 Google Cloud 콘솔에서 Cloud Run Functions를 삭제할 수 있습니다.