github.com/pingcap/tiflow@v0.0.0-20240520035814-5bf52d54e205/docs/swagger/swagger.yaml (about)

     1  definitions:
     2    config.CSVConfig:
     3      properties:
     4        binary-encoding-method:
     5          description: encoding method of binary type
     6          type: string
     7        delimiter:
     8          description: |-
     9            delimiter between fields, it can be 1 character or at most 2 characters
    10            It can not be CR or LF or contains CR or LF.
    11            It should have exclusive characters with quote.
    12          type: string
    13        include-commit-ts:
    14          description: whether to include commit ts
    15          type: boolean
    16        "null":
    17          description: representation of null values
    18          type: string
    19        output-handle-key:
    20          description: output handle key
    21          type: boolean
    22        output-old-value:
    23          description: output old value
    24          type: boolean
    25        quote:
    26          description: quoting character
    27          type: string
    28      type: object
    29    config.CloudStorageConfig:
    30      properties:
    31        file-cleanup-cron-spec:
    32          type: string
    33        file-expiration-days:
    34          type: integer
    35        file-size:
    36          type: integer
    37        flush-concurrency:
    38          type: integer
    39        flush-interval:
    40          type: string
    41        output-column-id:
    42          type: boolean
    43        worker-count:
    44          type: integer
    45      type: object
    46    config.CodecConfig:
    47      properties:
    48        avro-bigint-unsigned-handling-mode:
    49          type: string
    50        avro-decimal-handling-mode:
    51          type: string
    52        avro-enable-watermark:
    53          type: boolean
    54        enable-tidb-extension:
    55          type: boolean
    56        encoding-format:
    57          type: string
    58        max-batch-size:
    59          type: integer
    60      type: object
    61    config.ColumnSelector:
    62      properties:
    63        columns:
    64          items:
    65            type: string
    66          type: array
    67        matcher:
    68          items:
    69            type: string
    70          type: array
    71      type: object
    72    config.DebeziumConfig:
    73      properties:
    74        output-old-value:
    75          type: boolean
    76      type: object
    77    config.DispatchRule:
    78      properties:
    79        columns:
    80          description: Columns are set when using columns dispatcher.
    81          items:
    82            type: string
    83          type: array
    84        dispatcher:
    85          description: Deprecated, please use PartitionRule.
    86          type: string
    87        index:
    88          description: IndexName is set when using index-value dispatcher with specified
    89            index.
    90          type: string
    91        matcher:
    92          items:
    93            type: string
    94          type: array
    95        partition:
    96          description: |-
    97            PartitionRule is an alias added for DispatcherRule to mitigate confusions.
    98            In the future release, the DispatcherRule is expected to be removed .
    99          type: string
   100        topic:
   101          type: string
   102      type: object
   103    config.GlueSchemaRegistryConfig:
   104      properties:
   105        access-key:
   106          description: AccessKey of the schema registry
   107          type: string
   108        region:
   109          description: Region of the schema registry
   110          type: string
   111        registry-name:
   112          description: Name of the schema registry
   113          type: string
   114        secret-access-key:
   115          description: SecretAccessKey of the schema registry
   116          type: string
   117        token:
   118          type: string
   119      type: object
   120    config.KafkaConfig:
   121      properties:
   122        auto-create-topic:
   123          type: boolean
   124        ca:
   125          type: string
   126        cert:
   127          type: string
   128        codec-config:
   129          $ref: '#/definitions/config.CodecConfig'
   130        compression:
   131          type: string
   132        dial-timeout:
   133          type: string
   134        enable-tls:
   135          type: boolean
   136        glue-schema-registry-config:
   137          $ref: '#/definitions/config.GlueSchemaRegistryConfig'
   138        insecure-skip-verify:
   139          type: boolean
   140        kafka-client-id:
   141          type: string
   142        kafka-version:
   143          type: string
   144        key:
   145          type: string
   146        large-message-handle:
   147          $ref: '#/definitions/config.LargeMessageHandleConfig'
   148        max-message-bytes:
   149          type: integer
   150        partition-num:
   151          type: integer
   152        read-timeout:
   153          type: string
   154        replication-factor:
   155          type: integer
   156        required-acks:
   157          type: integer
   158        sasl-gssapi-auth-type:
   159          type: string
   160        sasl-gssapi-disable-pafxfast:
   161          type: boolean
   162        sasl-gssapi-kerberos-config-path:
   163          type: string
   164        sasl-gssapi-keytab-path:
   165          type: string
   166        sasl-gssapi-password:
   167          type: string
   168        sasl-gssapi-realm:
   169          type: string
   170        sasl-gssapi-service-name:
   171          type: string
   172        sasl-gssapi-user:
   173          type: string
   174        sasl-mechanism:
   175          type: string
   176        sasl-oauth-audience:
   177          type: string
   178        sasl-oauth-client-id:
   179          type: string
   180        sasl-oauth-client-secret:
   181          type: string
   182        sasl-oauth-grant-type:
   183          type: string
   184        sasl-oauth-scopes:
   185          items:
   186            type: string
   187          type: array
   188        sasl-oauth-token-url:
   189          type: string
   190        sasl-password:
   191          type: string
   192        sasl-user:
   193          type: string
   194        write-timeout:
   195          type: string
   196      type: object
   197    config.LargeMessageHandleConfig:
   198      properties:
   199        claim-check-storage-uri:
   200          type: string
   201        large-message-handle-compression:
   202          type: string
   203        large-message-handle-option:
   204          type: string
   205      type: object
   206    config.MySQLConfig:
   207      properties:
   208        enable-batch-dml:
   209          type: boolean
   210        enable-cache-prepared-statement:
   211          type: boolean
   212        enable-multi-statement:
   213          type: boolean
   214        max-multi-update-row:
   215          type: integer
   216        max-multi-update-row-size:
   217          type: integer
   218        max-txn-row:
   219          type: integer
   220        read-timeout:
   221          type: string
   222        ssl-ca:
   223          type: string
   224        ssl-cert:
   225          type: string
   226        ssl-key:
   227          type: string
   228        tidb-txn-mode:
   229          type: string
   230        time-zone:
   231          type: string
   232        timeout:
   233          type: string
   234        worker-count:
   235          type: integer
   236        write-timeout:
   237          type: string
   238      type: object
   239    config.OAuth2:
   240      properties:
   241        oauth2-audience:
   242          description: OAuth2Audience  the URL of the resource server.
   243          type: string
   244        oauth2-client-id:
   245          description: OAuth2ClientID  the client ID of the application.
   246          type: string
   247        oauth2-issuer-url:
   248          description: OAuth2IssuerURL  the URL of the authorization server.
   249          type: string
   250        oauth2-private-key:
   251          description: OAuth2PrivateKey the private key used to sign the server.
   252          type: string
   253        oauth2-scope:
   254          description: OAuth2Scope scope
   255          type: string
   256      type: object
   257    config.OpenProtocolConfig:
   258      properties:
   259        output-old-value:
   260          type: boolean
   261      type: object
   262    config.PulsarConfig:
   263      properties:
   264        auth-tls-certificate-path:
   265          description: AuthTLSCertificatePath  create new pulsar authentication provider
   266            with specified TLS certificate and private key
   267          type: string
   268        auth-tls-private-key-path:
   269          description: AuthTLSPrivateKeyPath private key
   270          type: string
   271        authentication-token:
   272          description: AuthenticationToken the token for the Pulsar server
   273          type: string
   274        basic-password:
   275          description: BasicPassword with account
   276          type: string
   277        basic-user-name:
   278          description: BasicUserName Account name for pulsar basic authentication (the
   279            second priority authentication method)
   280          type: string
   281        batching-max-messages:
   282          description: 'BatchingMaxMessages specifies the maximum number of messages
   283            permitted in a batch. (default: 1000)'
   284          type: integer
   285        batching-max-publish-delay:
   286          description: |-
   287            BatchingMaxPublishDelay specifies the time period within which the messages sent will be batched (default: 10ms)
   288            if batch messages are enabled. If set to a non zero value, messages will be queued until this time
   289            interval or until
   290          type: integer
   291        compression-type:
   292          description: pulsar client compression
   293          type: string
   294        connection-timeout:
   295          description: 'ConnectionTimeout Timeout for the establishment of a TCP connection
   296            (default: 5 seconds)'
   297          type: integer
   298        oauth2:
   299          $ref: '#/definitions/config.OAuth2'
   300          description: |-
   301            Oauth2 include  oauth2-issuer-url oauth2-audience oauth2-private-key oauth2-client-id
   302            and 'type' always use 'client_credentials'
   303        operation-timeout:
   304          description: |-
   305            Set the operation timeout (default: 30 seconds)
   306            Producer-create, subscribe and unsubscribe operations will be retried until this interval, after which the
   307            operation will be marked as failed
   308          type: integer
   309        pulsar-producer-cache-size:
   310          description: PulsarProducerCacheSize is the size of the cache of pulsar producers
   311          type: integer
   312        pulsar-version:
   313          description: PulsarVersion print the version of pulsar
   314          type: string
   315        send-timeout:
   316          description: |-
   317            SendTimeout specifies the timeout for a message that has not been acknowledged by the server since sent.
   318            Send and SendAsync returns an error after timeout.
   319            default: 30s
   320          type: integer
   321        tls-certificate-file:
   322          type: string
   323        tls-key-file-path:
   324          type: string
   325        tls-trust-certs-file-path:
   326          type: string
   327        token-from-file:
   328          description: |-
   329            TokenFromFile Authentication from the file token,
   330            the path name of the file (the third priority authentication method)
   331          type: string
   332      type: object
   333    config.SinkConfig:
   334      properties:
   335        advance-timeout-in-sec:
   336          description: |-
   337            AdvanceTimeoutInSec is a duration in second. If a table sink progress hasn't been
   338            advanced for this given duration, the sink will be canceled and re-established.
   339          type: integer
   340        cloud-storage-config:
   341          $ref: '#/definitions/config.CloudStorageConfig'
   342        column-selectors:
   343          items:
   344            $ref: '#/definitions/config.ColumnSelector'
   345          type: array
   346        content-compatible:
   347          description: ContentCompatible is only available when the downstream is MQ.
   348          type: boolean
   349        csv:
   350          $ref: '#/definitions/config.CSVConfig'
   351          description: CSVConfig is only available when the downstream is Storage.
   352        date-separator:
   353          description: DateSeparator is only available when the downstream is Storage.
   354          type: string
   355        debezium:
   356          $ref: '#/definitions/config.DebeziumConfig'
   357          description: DebeziumConfig related configurations
   358        debezium-disable-schema:
   359          description: Debezium only. Whether schema should be excluded in the output.
   360          type: boolean
   361        delete-only-output-handle-key-columns:
   362          description: DeleteOnlyOutputHandleKeyColumns is only available when the downstream
   363            is MQ.
   364          type: boolean
   365        dispatchers:
   366          description: DispatchRules is only available when the downstream is MQ.
   367          items:
   368            $ref: '#/definitions/config.DispatchRule'
   369          type: array
   370        enable-kafka-sink-v2:
   371          description: |-
   372            EnableKafkaSinkV2 enabled then the kafka-go sink will be used.
   373            It is only available when the downstream is MQ.
   374          type: boolean
   375        enable-partition-separator:
   376          description: EnablePartitionSeparator is only available when the downstream
   377            is Storage.
   378          type: boolean
   379        encoder-concurrency:
   380          description: EncoderConcurrency is only available when the downstream is MQ.
   381          type: integer
   382        file-index-digit:
   383          description: FileIndexWidth is only available when the downstream is Storage
   384          type: integer
   385        kafka-config:
   386          $ref: '#/definitions/config.KafkaConfig'
   387        mysql-config:
   388          $ref: '#/definitions/config.MySQLConfig'
   389        only-output-updated-columns:
   390          description: OnlyOutputUpdatedColumns is only available when the downstream
   391            is MQ.
   392          type: boolean
   393        open:
   394          $ref: '#/definitions/config.OpenProtocolConfig'
   395          description: OpenProtocol related configurations
   396        protocol:
   397          description: Protocol is NOT available when the downstream is DB.
   398          type: string
   399        pulsar-config:
   400          $ref: '#/definitions/config.PulsarConfig'
   401        safe-mode:
   402          description: SafeMode is only available when the downstream is DB.
   403          type: boolean
   404        schema-registry:
   405          description: SchemaRegistry is only available when the downstream is MQ using
   406            avro protocol.
   407          type: string
   408        send-bootstrap-in-msg-count:
   409          description: SendBootstrapInMsgCount means bootstrap messages are being sent
   410            every SendBootstrapInMsgCount row change messages.
   411          type: integer
   412        send-bootstrap-interval-in-sec:
   413          description: |-
   414            Simple Protocol only config, use to control the behavior of sending bootstrap message.
   415            Note: When one of the following conditions is set to negative value,
   416            bootstrap sending function will be disabled.
   417            SendBootstrapIntervalInSec is the interval in seconds to send bootstrap message.
   418          type: integer
   419        send-bootstrap-to-all-partition:
   420          description: |-
   421            SendBootstrapToAllPartition determines whether to send bootstrap message to all partitions.
   422            If set to false, bootstrap message will only be sent to the first partition of each topic.
   423            Default value is true.
   424          type: boolean
   425        terminator:
   426          description: Terminator is NOT available when the downstream is DB.
   427          type: string
   428        transaction-atomicity:
   429          type: string
   430      type: object
   431    model.Capture:
   432      properties:
   433        address:
   434          type: string
   435        cluster_id:
   436          type: string
   437        id:
   438          type: string
   439        is_owner:
   440          type: boolean
   441      type: object
   442    model.CaptureTaskStatus:
   443      properties:
   444        capture_id:
   445          type: string
   446        table_ids:
   447          description: Table list, containing tables that processor should process
   448          items:
   449            type: integer
   450          type: array
   451        table_operations:
   452          additionalProperties:
   453            $ref: '#/definitions/model.TableOperation'
   454          type: object
   455      type: object
   456    model.ChangefeedCommonInfo:
   457      properties:
   458        checkpoint_time:
   459          type: string
   460        checkpoint_tso:
   461          type: integer
   462        error:
   463          $ref: '#/definitions/model.RunningError'
   464        id:
   465          type: string
   466        namespace:
   467          type: string
   468        state:
   469          type: string
   470        upstream_id:
   471          type: integer
   472      type: object
   473    model.ChangefeedConfig:
   474      properties:
   475        changefeed_id:
   476          type: string
   477        filter_rules:
   478          items:
   479            type: string
   480          type: array
   481        force_replicate:
   482          default: false
   483          description: if true, force to replicate some ineligible tables
   484          type: boolean
   485        ignore_ineligible_table:
   486          default: false
   487          type: boolean
   488        ignore_txn_start_ts:
   489          items:
   490            type: integer
   491          type: array
   492        mounter_worker_num:
   493          default: 16
   494          type: integer
   495        namespace:
   496          type: string
   497        sink_config:
   498          $ref: '#/definitions/config.SinkConfig'
   499        sink_uri:
   500          type: string
   501        start_ts:
   502          type: integer
   503        target_ts:
   504          type: integer
   505        timezone:
   506          default: system
   507          description: timezone used when checking sink uri
   508          type: string
   509      type: object
   510    model.ChangefeedDetail:
   511      properties:
   512        checkpoint_time:
   513          type: string
   514        checkpoint_tso:
   515          type: integer
   516        create_time:
   517          type: string
   518        creator_version:
   519          type: string
   520        error:
   521          $ref: '#/definitions/model.RunningError'
   522        error_history:
   523          items:
   524            type: integer
   525          type: array
   526        id:
   527          type: string
   528        namespace:
   529          type: string
   530        resolved_ts:
   531          type: integer
   532        sink_uri:
   533          type: string
   534        sort_engine:
   535          type: string
   536        start_ts:
   537          type: integer
   538        state:
   539          type: string
   540        target_ts:
   541          type: integer
   542        task_status:
   543          items:
   544            $ref: '#/definitions/model.CaptureTaskStatus'
   545          type: array
   546        upstream_id:
   547          type: integer
   548      type: object
   549    model.HTTPError:
   550      properties:
   551        error_code:
   552          type: string
   553        error_msg:
   554          type: string
   555      type: object
   556    model.MoveTableReq:
   557      properties:
   558        capture_id:
   559          type: string
   560        table_id:
   561          type: integer
   562      type: object
   563    model.ProcessorCommonInfo:
   564      properties:
   565        capture_id:
   566          type: string
   567        changefeed_id:
   568          type: string
   569        namespace:
   570          type: string
   571      type: object
   572    model.ProcessorDetail:
   573      properties:
   574        table_ids:
   575          description: All table ids that this processor are replicating.
   576          items:
   577            type: integer
   578          type: array
   579      type: object
   580    model.RunningError:
   581      properties:
   582        addr:
   583          type: string
   584        code:
   585          type: string
   586        message:
   587          type: string
   588        time:
   589          type: string
   590      type: object
   591    model.ServerStatus:
   592      properties:
   593        cluster_id:
   594          type: string
   595        git_hash:
   596          type: string
   597        id:
   598          type: string
   599        is_owner:
   600          type: boolean
   601        liveness:
   602          type: integer
   603        pid:
   604          type: integer
   605        version:
   606          type: string
   607      type: object
   608    model.TableOperation:
   609      properties:
   610        boundary_ts:
   611          description: |-
   612            if the operation is a delete operation, BoundaryTs is checkpoint ts
   613            if the operation is an add operation, BoundaryTs is start ts
   614          type: integer
   615        delete:
   616          type: boolean
   617        flag:
   618          type: integer
   619        status:
   620          type: integer
   621      type: object
   622    v2.CSVConfig:
   623      properties:
   624        binary_encoding_method:
   625          type: string
   626        delimiter:
   627          type: string
   628        include_commit_ts:
   629          type: boolean
   630        "null":
   631          type: string
   632        output_handle_key:
   633          type: boolean
   634        output_old_value:
   635          type: boolean
   636        quote:
   637          type: string
   638      type: object
   639    v2.Capture:
   640      properties:
   641        address:
   642          type: string
   643        cluster_id:
   644          type: string
   645        id:
   646          type: string
   647        is_owner:
   648          type: boolean
   649      type: object
   650    v2.ChangeFeedInfo:
   651      properties:
   652        admin_job_type:
   653          description: used for admin job notification, trigger watch event in capture
   654          type: integer
   655        checkpoint_time:
   656          type: string
   657        checkpoint_ts:
   658          type: integer
   659        config:
   660          $ref: '#/definitions/v2.ReplicaConfig'
   661        create_time:
   662          type: string
   663        creator_version:
   664          type: string
   665        error:
   666          $ref: '#/definitions/v2.RunningError'
   667        id:
   668          type: string
   669        namespace:
   670          type: string
   671        resolved_ts:
   672          type: integer
   673        sink_uri:
   674          type: string
   675        start_ts:
   676          description: Start sync at this commit ts if `StartTs` is specify or using
   677            the CreateTime of changefeed.
   678          type: integer
   679        state:
   680          type: string
   681        target_ts:
   682          description: The ChangeFeed will exits until sync to timestamp TargetTs
   683          type: integer
   684        task_status:
   685          items:
   686            $ref: '#/definitions/model.CaptureTaskStatus'
   687          type: array
   688        upstream_id:
   689          type: integer
   690      type: object
   691    v2.ChangefeedCommonInfo:
   692      properties:
   693        checkpoint_time:
   694          type: string
   695        checkpoint_tso:
   696          type: integer
   697        error:
   698          $ref: '#/definitions/model.RunningError'
   699        id:
   700          type: string
   701        namespace:
   702          type: string
   703        state:
   704          type: string
   705        upstream_id:
   706          type: integer
   707      type: object
   708    v2.ChangefeedConfig:
   709      properties:
   710        ca_path:
   711          type: string
   712        cert_allowed_cn:
   713          items:
   714            type: string
   715          type: array
   716        cert_path:
   717          type: string
   718        changefeed_id:
   719          type: string
   720        key_path:
   721          type: string
   722        namespace:
   723          type: string
   724        pd_addrs:
   725          items:
   726            type: string
   727          type: array
   728        replica_config:
   729          $ref: '#/definitions/v2.ReplicaConfig'
   730        sink_uri:
   731          type: string
   732        start_ts:
   733          type: integer
   734        target_ts:
   735          type: integer
   736      type: object
   737    v2.ChangefeedSchedulerConfig:
   738      properties:
   739        enable_table_across_nodes:
   740          description: |-
   741            EnableTableAcrossNodes set true to split one table to multiple spans and
   742            distribute to multiple TiCDC nodes.
   743          type: boolean
   744        region_threshold:
   745          description: RegionThreshold is the region count threshold of splitting a
   746            table.
   747          type: integer
   748        write_key_threshold:
   749          description: WriteKeyThreshold is the written keys threshold of splitting
   750            a table.
   751          type: integer
   752      type: object
   753    v2.CloudStorageConfig:
   754      properties:
   755        file_cleanup_cron_spec:
   756          type: string
   757        file_expiration_days:
   758          type: integer
   759        file_size:
   760          type: integer
   761        flush_concurrency:
   762          type: integer
   763        flush_interval:
   764          type: string
   765        output_column_id:
   766          type: boolean
   767        worker_count:
   768          type: integer
   769      type: object
   770    v2.CodecConfig:
   771      properties:
   772        avro_bigint_unsigned_handling_mode:
   773          type: string
   774        avro_decimal_handling_mode:
   775          type: string
   776        avro_enable_watermark:
   777          type: boolean
   778        enable_tidb_extension:
   779          type: boolean
   780        encoding_format:
   781          type: string
   782        max_batch_size:
   783          type: integer
   784      type: object
   785    v2.ColumnSelector:
   786      properties:
   787        columns:
   788          items:
   789            type: string
   790          type: array
   791        matcher:
   792          items:
   793            type: string
   794          type: array
   795      type: object
   796    v2.ConsistentConfig:
   797      properties:
   798        compression:
   799          type: string
   800        encoding_worker_num:
   801          type: integer
   802        flush_concurrency:
   803          type: integer
   804        flush_interval:
   805          type: integer
   806        flush_worker_num:
   807          type: integer
   808        level:
   809          type: string
   810        max_log_size:
   811          type: integer
   812        memory_usage:
   813          $ref: '#/definitions/v2.ConsistentMemoryUsage'
   814        meta_flush_interval:
   815          type: integer
   816        storage:
   817          type: string
   818        use_file_backend:
   819          type: boolean
   820      type: object
   821    v2.ConsistentMemoryUsage:
   822      properties:
   823        memory_quota_percentage:
   824          type: integer
   825      type: object
   826    v2.DebeziumConfig:
   827      properties:
   828        output_old_value:
   829          type: boolean
   830      type: object
   831    v2.DispatchRule:
   832      properties:
   833        columns:
   834          items:
   835            type: string
   836          type: array
   837        index:
   838          type: string
   839        matcher:
   840          items:
   841            type: string
   842          type: array
   843        partition:
   844          type: string
   845        topic:
   846          type: string
   847      type: object
   848    v2.EmptyResponse:
   849      type: object
   850    v2.EventFilterRule:
   851      properties:
   852        ignore_delete_value_expr:
   853          type: string
   854        ignore_event:
   855          items:
   856            type: string
   857          type: array
   858        ignore_insert_value_expr:
   859          description: sql expression
   860          type: string
   861        ignore_sql:
   862          description: regular expression
   863          items:
   864            type: string
   865          type: array
   866        ignore_update_new_value_expr:
   867          type: string
   868        ignore_update_old_value_expr:
   869          type: string
   870        matcher:
   871          items:
   872            type: string
   873          type: array
   874      type: object
   875    v2.FilterConfig:
   876      properties:
   877        event_filters:
   878          items:
   879            $ref: '#/definitions/v2.EventFilterRule'
   880          type: array
   881        ignore_txn_start_ts:
   882          items:
   883            type: integer
   884          type: array
   885        rules:
   886          items:
   887            type: string
   888          type: array
   889      type: object
   890    v2.GlueSchemaRegistryConfig:
   891      properties:
   892        access_key:
   893          description: AccessKey of the schema registry
   894          type: string
   895        region:
   896          description: Region of the schema registry
   897          type: string
   898        registry_name:
   899          description: Name of the schema registry
   900          type: string
   901        secret_access_key:
   902          description: SecretAccessKey of the schema registry
   903          type: string
   904        token:
   905          type: string
   906      type: object
   907    v2.IntegrityConfig:
   908      properties:
   909        corruption_handle_level:
   910          type: string
   911        integrity_check_level:
   912          type: string
   913      type: object
   914    v2.JSONDuration:
   915      type: object
   916    v2.KafkaConfig:
   917      properties:
   918        auto_create_topic:
   919          type: boolean
   920        ca:
   921          type: string
   922        cert:
   923          type: string
   924        codec_config:
   925          $ref: '#/definitions/v2.CodecConfig'
   926        compression:
   927          type: string
   928        dial_timeout:
   929          type: string
   930        enable_tls:
   931          type: boolean
   932        glue_schema_registry_config:
   933          $ref: '#/definitions/v2.GlueSchemaRegistryConfig'
   934        insecure_skip_verify:
   935          type: boolean
   936        kafka_client_id:
   937          type: string
   938        kafka_version:
   939          type: string
   940        key:
   941          type: string
   942        large_message_handle:
   943          $ref: '#/definitions/v2.LargeMessageHandleConfig'
   944        max_message_bytes:
   945          type: integer
   946        partition_num:
   947          type: integer
   948        read_timeout:
   949          type: string
   950        replication_factor:
   951          type: integer
   952        required_acks:
   953          type: integer
   954        sasl_gssapi_auth_type:
   955          type: string
   956        sasl_gssapi_disable_pafxfast:
   957          type: boolean
   958        sasl_gssapi_kerberos_config_path:
   959          type: string
   960        sasl_gssapi_keytab_path:
   961          type: string
   962        sasl_gssapi_password:
   963          type: string
   964        sasl_gssapi_realm:
   965          type: string
   966        sasl_gssapi_service_name:
   967          type: string
   968        sasl_gssapi_user:
   969          type: string
   970        sasl_mechanism:
   971          type: string
   972        sasl_oauth_audience:
   973          type: string
   974        sasl_oauth_client_id:
   975          type: string
   976        sasl_oauth_client_secret:
   977          type: string
   978        sasl_oauth_grant_type:
   979          type: string
   980        sasl_oauth_scopes:
   981          items:
   982            type: string
   983          type: array
   984        sasl_oauth_token_url:
   985          type: string
   986        sasl_password:
   987          type: string
   988        sasl_user:
   989          type: string
   990        write_timeout:
   991          type: string
   992      type: object
   993    v2.LargeMessageHandleConfig:
   994      properties:
   995        claim_check_storage_uri:
   996          type: string
   997        large_message_handle_compression:
   998          type: string
   999        large_message_handle_option:
  1000          type: string
  1001      type: object
  1002    v2.LogLevelReq:
  1003      properties:
  1004        log_level:
  1005          type: string
  1006      type: object
  1007    v2.MounterConfig:
  1008      properties:
  1009        worker_num:
  1010          type: integer
  1011      type: object
  1012    v2.MySQLConfig:
  1013      properties:
  1014        enable_batch_dml:
  1015          type: boolean
  1016        enable_cache_prepared_statement:
  1017          type: boolean
  1018        enable_multi_statement:
  1019          type: boolean
  1020        max_multi_update_row_count:
  1021          type: integer
  1022        max_multi_update_row_size:
  1023          type: integer
  1024        max_txn_row:
  1025          type: integer
  1026        read_timeout:
  1027          type: string
  1028        ssl_ca:
  1029          type: string
  1030        ssl_cert:
  1031          type: string
  1032        ssl_key:
  1033          type: string
  1034        tidb_txn_mode:
  1035          type: string
  1036        time_zone:
  1037          type: string
  1038        timeout:
  1039          type: string
  1040        worker_count:
  1041          type: integer
  1042        write_timeout:
  1043          type: string
  1044      type: object
  1045    v2.OpenProtocolConfig:
  1046      properties:
  1047        output_old_value:
  1048          type: boolean
  1049      type: object
  1050    v2.ProcessorCommonInfo:
  1051      properties:
  1052        capture_id:
  1053          type: string
  1054        changefeed_id:
  1055          type: string
  1056        namespace:
  1057          type: string
  1058      type: object
  1059    v2.ProcessorDetail:
  1060      properties:
  1061        table_ids:
  1062          description: All table ids that this processor are replicating.
  1063          items:
  1064            type: integer
  1065          type: array
  1066      type: object
  1067    v2.PulsarConfig:
  1068      properties:
  1069        auth-tls-certificate-path:
  1070          type: string
  1071        auth-tls-private-key-path:
  1072          type: string
  1073        authentication-token:
  1074          type: string
  1075        basic-password:
  1076          type: string
  1077        basic-user-name:
  1078          type: string
  1079        batching-max-messages:
  1080          type: integer
  1081        batching-max-publish-delay:
  1082          type: integer
  1083        compression-type:
  1084          type: string
  1085        connection-timeout:
  1086          type: integer
  1087        oauth2:
  1088          $ref: '#/definitions/v2.PulsarOAuth2'
  1089        operation-timeout:
  1090          type: integer
  1091        pulsar-producer-cache-size:
  1092          type: integer
  1093        pulsar-version:
  1094          type: string
  1095        send-timeout:
  1096          type: integer
  1097        tls-certificate-path:
  1098          type: string
  1099        tls-private-key-path:
  1100          type: string
  1101        tls-trust-certs-file-path:
  1102          type: string
  1103        token-from-file:
  1104          type: string
  1105      type: object
  1106    v2.PulsarOAuth2:
  1107      properties:
  1108        oauth2-audience:
  1109          type: string
  1110        oauth2-client-id:
  1111          type: string
  1112        oauth2-issuer-url:
  1113          type: string
  1114        oauth2-private-key:
  1115          type: string
  1116        oauth2-scope:
  1117          type: string
  1118      type: object
  1119    v2.ReplicaConfig:
  1120      properties:
  1121        bdr_mode:
  1122          type: boolean
  1123        case_sensitive:
  1124          type: boolean
  1125        changefeed_error_stuck_duration:
  1126          $ref: '#/definitions/v2.JSONDuration'
  1127        check_gc_safe_point:
  1128          type: boolean
  1129        consistent:
  1130          $ref: '#/definitions/v2.ConsistentConfig'
  1131        enable_sync_point:
  1132          type: boolean
  1133        enable_table_monitor:
  1134          type: boolean
  1135        filter:
  1136          $ref: '#/definitions/v2.FilterConfig'
  1137        force_replicate:
  1138          type: boolean
  1139        ignore_ineligible_table:
  1140          type: boolean
  1141        integrity:
  1142          $ref: '#/definitions/v2.IntegrityConfig'
  1143        memory_quota:
  1144          type: integer
  1145        mounter:
  1146          $ref: '#/definitions/v2.MounterConfig'
  1147        scheduler:
  1148          $ref: '#/definitions/v2.ChangefeedSchedulerConfig'
  1149        sink:
  1150          $ref: '#/definitions/v2.SinkConfig'
  1151        sql_mode:
  1152          description: 'Deprecated: we don''t use this field since v8.0.0.'
  1153          type: string
  1154        sync_point_interval:
  1155          type: string
  1156        sync_point_retention:
  1157          type: string
  1158        synced_status:
  1159          $ref: '#/definitions/v2.SyncedStatusConfig'
  1160      type: object
  1161    v2.ResumeChangefeedConfig:
  1162      properties:
  1163        ca_path:
  1164          type: string
  1165        cert_allowed_cn:
  1166          items:
  1167            type: string
  1168          type: array
  1169        cert_path:
  1170          type: string
  1171        key_path:
  1172          type: string
  1173        overwrite_checkpoint_ts:
  1174          type: integer
  1175        pd_addrs:
  1176          items:
  1177            type: string
  1178          type: array
  1179      type: object
  1180    v2.RunningError:
  1181      properties:
  1182        addr:
  1183          type: string
  1184        code:
  1185          type: string
  1186        message:
  1187          type: string
  1188        time:
  1189          type: string
  1190      type: object
  1191    v2.ServerStatus:
  1192      properties:
  1193        cluster_id:
  1194          type: string
  1195        git_hash:
  1196          type: string
  1197        id:
  1198          type: string
  1199        is_owner:
  1200          type: boolean
  1201        liveness:
  1202          type: integer
  1203        pid:
  1204          type: integer
  1205        version:
  1206          type: string
  1207      type: object
  1208    v2.SinkConfig:
  1209      properties:
  1210        advance_timeout:
  1211          type: integer
  1212        cloud_storage_config:
  1213          $ref: '#/definitions/v2.CloudStorageConfig'
  1214        column_selectors:
  1215          items:
  1216            $ref: '#/definitions/v2.ColumnSelector'
  1217          type: array
  1218        content_compatible:
  1219          type: boolean
  1220        csv:
  1221          $ref: '#/definitions/v2.CSVConfig'
  1222        date_separator:
  1223          type: string
  1224        debezium:
  1225          $ref: '#/definitions/v2.DebeziumConfig'
  1226        debezium_disable_schema:
  1227          type: boolean
  1228        delete_only_output_handle_key_columns:
  1229          type: boolean
  1230        dispatchers:
  1231          items:
  1232            $ref: '#/definitions/v2.DispatchRule'
  1233          type: array
  1234        enable_kafka_sink_v2:
  1235          type: boolean
  1236        enable_partition_separator:
  1237          type: boolean
  1238        encoder_concurrency:
  1239          type: integer
  1240        file_index_width:
  1241          type: integer
  1242        kafka_config:
  1243          $ref: '#/definitions/v2.KafkaConfig'
  1244        mysql_config:
  1245          $ref: '#/definitions/v2.MySQLConfig'
  1246        only_output_updated_columns:
  1247          type: boolean
  1248        open:
  1249          $ref: '#/definitions/v2.OpenProtocolConfig'
  1250        protocol:
  1251          type: string
  1252        pulsar_config:
  1253          $ref: '#/definitions/v2.PulsarConfig'
  1254        safe_mode:
  1255          type: boolean
  1256        schema_registry:
  1257          type: string
  1258        send_bootstrap_in_msg_count:
  1259          type: integer
  1260        send_bootstrap_interval_in_sec:
  1261          type: integer
  1262        send_bootstrap_to_all_partition:
  1263          type: boolean
  1264        terminator:
  1265          type: string
  1266        transaction_atomicity:
  1267          type: string
  1268      type: object
  1269    v2.SyncedStatus:
  1270      properties:
  1271        info:
  1272          type: string
  1273        last_synced_ts:
  1274          type: string
  1275        now_ts:
  1276          type: string
  1277        puller_resolved_ts:
  1278          type: string
  1279        sink_checkpoint_ts:
  1280          type: string
  1281        synced:
  1282          type: boolean
  1283      type: object
  1284    v2.SyncedStatusConfig:
  1285      properties:
  1286        checkpoint_interval:
  1287          description: |-
  1288            The maximum interval between latest checkpoint ts and now or
  1289            between latest sink's checkpoint ts and puller's checkpoint ts required to reach synced state
  1290          type: integer
  1291        synced_check_interval:
  1292          description: The minimum interval between the latest synced ts and now required
  1293            to reach synced state
  1294          type: integer
  1295      type: object
  1296  info:
  1297    contact: {}
  1298  paths:
  1299    /api/v1/captures:
  1300      get:
  1301        consumes:
  1302        - application/json
  1303        description: list all captures in cdc cluster
  1304        produces:
  1305        - application/json
  1306        responses:
  1307          "200":
  1308            description: OK
  1309            schema:
  1310              items:
  1311                $ref: '#/definitions/model.Capture'
  1312              type: array
  1313          "400":
  1314            description: Bad Request
  1315            schema:
  1316              $ref: '#/definitions/model.HTTPError'
  1317          "500":
  1318            description: Internal Server Error
  1319            schema:
  1320              $ref: '#/definitions/model.HTTPError'
  1321        summary: List captures
  1322        tags:
  1323        - capture
  1324    /api/v1/captures/drain:
  1325      put:
  1326        consumes:
  1327        - application/json
  1328        description: Drain all tables at the target captures in cdc cluster
  1329        produces:
  1330        - application/json
  1331        responses:
  1332          "200":
  1333            description: ""
  1334          "202":
  1335            description: ""
  1336          "400":
  1337            description: Bad Request
  1338            schema:
  1339              $ref: '#/definitions/model.HTTPError'
  1340          "500":
  1341            description: Internal Server Error
  1342            schema:
  1343              $ref: '#/definitions/model.HTTPError'
  1344          "503":
  1345            description: Service Unavailable
  1346            schema:
  1347              $ref: '#/definitions/model.HTTPError'
  1348        summary: Drain captures
  1349        tags:
  1350        - capture
  1351    /api/v1/changefeeds:
  1352      get:
  1353        consumes:
  1354        - application/json
  1355        description: list all changefeeds in cdc cluster
  1356        parameters:
  1357        - description: state
  1358          in: query
  1359          name: state
  1360          type: string
  1361        produces:
  1362        - application/json
  1363        responses:
  1364          "200":
  1365            description: OK
  1366            schema:
  1367              items:
  1368                $ref: '#/definitions/model.ChangefeedCommonInfo'
  1369              type: array
  1370          "500":
  1371            description: Internal Server Error
  1372            schema:
  1373              $ref: '#/definitions/model.HTTPError'
  1374        summary: List changefeed
  1375        tags:
  1376        - changefeed
  1377      post:
  1378        consumes:
  1379        - application/json
  1380        description: create a new changefeed
  1381        parameters:
  1382        - description: changefeed config
  1383          in: body
  1384          name: changefeed
  1385          required: true
  1386          schema:
  1387            $ref: '#/definitions/model.ChangefeedConfig'
  1388        produces:
  1389        - application/json
  1390        responses:
  1391          "202":
  1392            description: ""
  1393          "400":
  1394            description: Bad Request
  1395            schema:
  1396              $ref: '#/definitions/model.HTTPError'
  1397          "500":
  1398            description: Internal Server Error
  1399            schema:
  1400              $ref: '#/definitions/model.HTTPError'
  1401        summary: Create changefeed
  1402        tags:
  1403        - changefeed
  1404    /api/v1/changefeeds/{changefeed_id}:
  1405      delete:
  1406        consumes:
  1407        - application/json
  1408        description: Remove a changefeed
  1409        parameters:
  1410        - description: changefeed_id
  1411          in: path
  1412          name: changefeed_id
  1413          required: true
  1414          type: string
  1415        produces:
  1416        - application/json
  1417        responses:
  1418          "202":
  1419            description: ""
  1420          "400":
  1421            description: Bad Request
  1422            schema:
  1423              $ref: '#/definitions/model.HTTPError'
  1424          "500":
  1425            description: Internal Server Error
  1426            schema:
  1427              $ref: '#/definitions/model.HTTPError'
  1428        summary: Remove a changefeed
  1429        tags:
  1430        - changefeed
  1431      get:
  1432        consumes:
  1433        - application/json
  1434        description: get detail information of a changefeed
  1435        parameters:
  1436        - description: changefeed_id
  1437          in: path
  1438          name: changefeed_id
  1439          required: true
  1440          type: string
  1441        produces:
  1442        - application/json
  1443        responses:
  1444          "200":
  1445            description: OK
  1446            schema:
  1447              $ref: '#/definitions/model.ChangefeedDetail'
  1448          "400":
  1449            description: Bad Request
  1450            schema:
  1451              $ref: '#/definitions/model.HTTPError'
  1452          "500":
  1453            description: Internal Server Error
  1454            schema:
  1455              $ref: '#/definitions/model.HTTPError'
  1456        summary: Get changefeed
  1457        tags:
  1458        - changefeed
  1459      put:
  1460        consumes:
  1461        - application/json
  1462        description: Update a changefeed
  1463        parameters:
  1464        - description: changefeed_id
  1465          in: path
  1466          name: changefeed_id
  1467          required: true
  1468          type: string
  1469        - description: changefeed config
  1470          in: body
  1471          name: changefeedConfig
  1472          required: true
  1473          schema:
  1474            $ref: '#/definitions/model.ChangefeedConfig'
  1475        produces:
  1476        - application/json
  1477        responses:
  1478          "202":
  1479            description: ""
  1480          "400":
  1481            description: Bad Request
  1482            schema:
  1483              $ref: '#/definitions/model.HTTPError'
  1484          "500":
  1485            description: Internal Server Error
  1486            schema:
  1487              $ref: '#/definitions/model.HTTPError'
  1488        summary: Update a changefeed
  1489        tags:
  1490        - changefeed
  1491    /api/v1/changefeeds/{changefeed_id}/pause:
  1492      post:
  1493        consumes:
  1494        - application/json
  1495        description: Pause a changefeed
  1496        parameters:
  1497        - description: changefeed_id
  1498          in: path
  1499          name: changefeed_id
  1500          required: true
  1501          type: string
  1502        produces:
  1503        - application/json
  1504        responses:
  1505          "202":
  1506            description: ""
  1507          "400":
  1508            description: Bad Request
  1509            schema:
  1510              $ref: '#/definitions/model.HTTPError'
  1511          "500":
  1512            description: Internal Server Error
  1513            schema:
  1514              $ref: '#/definitions/model.HTTPError'
  1515        summary: Pause a changefeed
  1516        tags:
  1517        - changefeed
  1518    /api/v1/changefeeds/{changefeed_id}/resume:
  1519      post:
  1520        consumes:
  1521        - application/json
  1522        description: Resume a changefeed
  1523        parameters:
  1524        - description: changefeed_id
  1525          in: path
  1526          name: changefeed_id
  1527          required: true
  1528          type: string
  1529        produces:
  1530        - application/json
  1531        responses:
  1532          "202":
  1533            description: ""
  1534          "400":
  1535            description: Bad Request
  1536            schema:
  1537              $ref: '#/definitions/model.HTTPError'
  1538          "500":
  1539            description: Internal Server Error
  1540            schema:
  1541              $ref: '#/definitions/model.HTTPError'
  1542        summary: Resume a changefeed
  1543        tags:
  1544        - changefeed
  1545    /api/v1/changefeeds/{changefeed_id}/tables/move_table:
  1546      post:
  1547        consumes:
  1548        - application/json
  1549        description: move one table to the target capture
  1550        parameters:
  1551        - description: changefeed_id
  1552          in: path
  1553          name: changefeed_id
  1554          required: true
  1555          type: string
  1556        - description: move table request
  1557          in: body
  1558          name: MoveTable
  1559          required: true
  1560          schema:
  1561            $ref: '#/definitions/model.MoveTableReq'
  1562        produces:
  1563        - application/json
  1564        responses:
  1565          "202":
  1566            description: ""
  1567          "400":
  1568            description: Bad Request
  1569            schema:
  1570              $ref: '#/definitions/model.HTTPError'
  1571          "500":
  1572            description: Internal Server Error
  1573            schema:
  1574              $ref: '#/definitions/model.HTTPError'
  1575        summary: move table
  1576        tags:
  1577        - changefeed
  1578    /api/v1/changefeeds/{changefeed_id}/tables/rebalance_table:
  1579      post:
  1580        consumes:
  1581        - application/json
  1582        description: rebalance all tables of a changefeed
  1583        parameters:
  1584        - description: changefeed_id
  1585          in: path
  1586          name: changefeed_id
  1587          required: true
  1588          type: string
  1589        produces:
  1590        - application/json
  1591        responses:
  1592          "202":
  1593            description: ""
  1594          "400":
  1595            description: Bad Request
  1596            schema:
  1597              $ref: '#/definitions/model.HTTPError'
  1598          "500":
  1599            description: Internal Server Error
  1600            schema:
  1601              $ref: '#/definitions/model.HTTPError'
  1602        summary: rebalance tables
  1603        tags:
  1604        - changefeed
  1605    /api/v1/health:
  1606      get:
  1607        consumes:
  1608        - application/json
  1609        description: check if CDC cluster is health
  1610        produces:
  1611        - application/json
  1612        responses:
  1613          "200":
  1614            description: ""
  1615          "500":
  1616            description: Internal Server Error
  1617            schema:
  1618              $ref: '#/definitions/model.HTTPError'
  1619        summary: Check if CDC cluster is health
  1620        tags:
  1621        - common
  1622    /api/v1/log:
  1623      post:
  1624        consumes:
  1625        - application/json
  1626        description: change TiCDC log level dynamically
  1627        parameters:
  1628        - description: log level
  1629          in: body
  1630          name: log_level
  1631          required: true
  1632          schema:
  1633            type: string
  1634        produces:
  1635        - application/json
  1636        responses:
  1637          "200":
  1638            description: ""
  1639          "400":
  1640            description: Bad Request
  1641            schema:
  1642              $ref: '#/definitions/model.HTTPError'
  1643        summary: Change TiCDC log level
  1644        tags:
  1645        - common
  1646    /api/v1/owner/resign:
  1647      post:
  1648        consumes:
  1649        - application/json
  1650        description: notify the current controller to resign
  1651        produces:
  1652        - application/json
  1653        responses:
  1654          "202":
  1655            description: ""
  1656          "400":
  1657            description: Bad Request
  1658            schema:
  1659              $ref: '#/definitions/model.HTTPError'
  1660          "500":
  1661            description: Internal Server Error
  1662            schema:
  1663              $ref: '#/definitions/model.HTTPError'
  1664        summary: notify the ticdc cluster controller to resign
  1665        tags:
  1666        - owner
  1667    /api/v1/processors:
  1668      get:
  1669        consumes:
  1670        - application/json
  1671        description: list all processors in the TiCDC cluster
  1672        produces:
  1673        - application/json
  1674        responses:
  1675          "200":
  1676            description: OK
  1677            schema:
  1678              items:
  1679                $ref: '#/definitions/model.ProcessorCommonInfo'
  1680              type: array
  1681          "400":
  1682            description: Bad Request
  1683            schema:
  1684              $ref: '#/definitions/model.HTTPError'
  1685          "500":
  1686            description: Internal Server Error
  1687            schema:
  1688              $ref: '#/definitions/model.HTTPError'
  1689        summary: List processors
  1690        tags:
  1691        - processor
  1692    /api/v1/processors/{changefeed_id}/{capture_id}:
  1693      get:
  1694        consumes:
  1695        - application/json
  1696        description: get the detail information of a processor
  1697        parameters:
  1698        - description: changefeed ID
  1699          in: path
  1700          name: changefeed_id
  1701          required: true
  1702          type: string
  1703        - description: capture ID
  1704          in: path
  1705          name: capture_id
  1706          required: true
  1707          type: string
  1708        produces:
  1709        - application/json
  1710        responses:
  1711          "200":
  1712            description: OK
  1713            schema:
  1714              $ref: '#/definitions/model.ProcessorDetail'
  1715          "400":
  1716            description: Bad Request
  1717            schema:
  1718              $ref: '#/definitions/model.HTTPError'
  1719          "500":
  1720            description: Internal Server Error
  1721            schema:
  1722              $ref: '#/definitions/model.HTTPError'
  1723        summary: Get processor detail information
  1724        tags:
  1725        - processor
  1726    /api/v1/status:
  1727      get:
  1728        consumes:
  1729        - application/json
  1730        description: get the status of a server(capture)
  1731        produces:
  1732        - application/json
  1733        responses:
  1734          "200":
  1735            description: OK
  1736            schema:
  1737              $ref: '#/definitions/model.ServerStatus'
  1738          "400":
  1739            description: Bad Request
  1740            schema:
  1741              $ref: '#/definitions/model.HTTPError'
  1742          "500":
  1743            description: Internal Server Error
  1744            schema:
  1745              $ref: '#/definitions/model.HTTPError'
  1746        summary: Get server status
  1747        tags:
  1748        - common
  1749    /api/v2/captures:
  1750      get:
  1751        description: list all captures in cdc cluster
  1752        produces:
  1753        - application/json
  1754        responses:
  1755          "200":
  1756            description: OK
  1757            schema:
  1758              items:
  1759                $ref: '#/definitions/v2.Capture'
  1760              type: array
  1761          "400":
  1762            description: Bad Request
  1763            schema:
  1764              $ref: '#/definitions/model.HTTPError'
  1765          "500":
  1766            description: Internal Server Error
  1767            schema:
  1768              $ref: '#/definitions/model.HTTPError'
  1769        summary: List captures
  1770        tags:
  1771        - capture
  1772        - v2
  1773    /api/v2/changefeeds:
  1774      get:
  1775        consumes:
  1776        - application/json
  1777        description: list all changefeeds in cdc cluster
  1778        parameters:
  1779        - description: state
  1780          in: query
  1781          name: state
  1782          type: string
  1783        - description: default
  1784          in: query
  1785          name: namespace
  1786          type: string
  1787        produces:
  1788        - application/json
  1789        responses:
  1790          "200":
  1791            description: OK
  1792            schema:
  1793              items:
  1794                $ref: '#/definitions/v2.ChangefeedCommonInfo'
  1795              type: array
  1796          "500":
  1797            description: Internal Server Error
  1798            schema:
  1799              $ref: '#/definitions/model.HTTPError'
  1800        summary: List changefeed
  1801        tags:
  1802        - changefeed
  1803        - v2
  1804      post:
  1805        consumes:
  1806        - application/json
  1807        description: create a new changefeed
  1808        parameters:
  1809        - description: changefeed config
  1810          in: body
  1811          name: changefeed
  1812          required: true
  1813          schema:
  1814            $ref: '#/definitions/v2.ChangefeedConfig'
  1815        produces:
  1816        - application/json
  1817        responses:
  1818          "200":
  1819            description: OK
  1820            schema:
  1821              $ref: '#/definitions/v2.ChangeFeedInfo'
  1822          "400":
  1823            description: Bad Request
  1824            schema:
  1825              $ref: '#/definitions/model.HTTPError'
  1826          "500":
  1827            description: Internal Server Error
  1828            schema:
  1829              $ref: '#/definitions/model.HTTPError'
  1830        summary: Create changefeed
  1831        tags:
  1832        - changefeed
  1833        - v2
  1834    /api/v2/changefeeds/{changefeed_id}:
  1835      delete:
  1836        consumes:
  1837        - application/json
  1838        description: Remove a changefeed
  1839        parameters:
  1840        - description: changefeed_id
  1841          in: path
  1842          name: changefeed_id
  1843          required: true
  1844          type: string
  1845        - description: default
  1846          in: query
  1847          name: namespace
  1848          type: string
  1849        produces:
  1850        - application/json
  1851        responses:
  1852          "200":
  1853            description: OK
  1854            schema:
  1855              $ref: '#/definitions/v2.EmptyResponse'
  1856          "400":
  1857            description: Bad Request
  1858            schema:
  1859              $ref: '#/definitions/model.HTTPError'
  1860          "500":
  1861            description: Internal Server Error
  1862            schema:
  1863              $ref: '#/definitions/model.HTTPError'
  1864        summary: Remove a changefeed
  1865        tags:
  1866        - changefeed
  1867        - v2
  1868      get:
  1869        consumes:
  1870        - application/json
  1871        description: get detail information of a changefeed
  1872        parameters:
  1873        - description: changefeed_id
  1874          in: path
  1875          name: changefeed_id
  1876          required: true
  1877          type: string
  1878        - description: default
  1879          in: query
  1880          name: namespace
  1881          type: string
  1882        produces:
  1883        - application/json
  1884        responses:
  1885          "200":
  1886            description: OK
  1887            schema:
  1888              $ref: '#/definitions/v2.ChangeFeedInfo'
  1889          "400":
  1890            description: Bad Request
  1891            schema:
  1892              $ref: '#/definitions/model.HTTPError'
  1893          "500":
  1894            description: Internal Server Error
  1895            schema:
  1896              $ref: '#/definitions/model.HTTPError'
  1897        summary: Get changefeed
  1898        tags:
  1899        - changefeed
  1900        - v2
  1901      put:
  1902        consumes:
  1903        - application/json
  1904        description: Update a changefeed
  1905        parameters:
  1906        - description: changefeed_id
  1907          in: path
  1908          name: changefeed_id
  1909          required: true
  1910          type: string
  1911        - description: default
  1912          in: query
  1913          name: namespace
  1914          type: string
  1915        - description: changefeed config
  1916          in: body
  1917          name: changefeedConfig
  1918          required: true
  1919          schema:
  1920            $ref: '#/definitions/v2.ChangefeedConfig'
  1921        produces:
  1922        - application/json
  1923        responses:
  1924          "200":
  1925            description: OK
  1926            schema:
  1927              $ref: '#/definitions/v2.ChangeFeedInfo'
  1928          "400":
  1929            description: Bad Request
  1930            schema:
  1931              $ref: '#/definitions/model.HTTPError'
  1932          "500":
  1933            description: Internal Server Error
  1934            schema:
  1935              $ref: '#/definitions/model.HTTPError'
  1936        summary: Update a changefeed
  1937        tags:
  1938        - changefeed
  1939        - v2
  1940    /api/v2/changefeeds/{changefeed_id}/pause:
  1941      post:
  1942        consumes:
  1943        - application/json
  1944        description: Pause a changefeed
  1945        parameters:
  1946        - description: changefeed_id
  1947          in: path
  1948          name: changefeed_id
  1949          required: true
  1950          type: string
  1951        - description: default
  1952          in: query
  1953          name: namespace
  1954          type: string
  1955        produces:
  1956        - application/json
  1957        responses:
  1958          "200":
  1959            description: OK
  1960            schema:
  1961              $ref: '#/definitions/v2.EmptyResponse'
  1962          "400":
  1963            description: Bad Request
  1964            schema:
  1965              $ref: '#/definitions/model.HTTPError'
  1966          "500":
  1967            description: Internal Server Error
  1968            schema:
  1969              $ref: '#/definitions/model.HTTPError'
  1970        summary: Pause a changefeed
  1971        tags:
  1972        - changefeed
  1973        - v2
  1974    /api/v2/changefeeds/{changefeed_id}/resume:
  1975      post:
  1976        consumes:
  1977        - application/json
  1978        description: Resume a changefeed
  1979        parameters:
  1980        - description: changefeed_id
  1981          in: path
  1982          name: changefeed_id
  1983          required: true
  1984          type: string
  1985        - description: default
  1986          in: query
  1987          name: namespace
  1988          type: string
  1989        - description: resume config
  1990          in: body
  1991          name: resumeConfig
  1992          required: true
  1993          schema:
  1994            $ref: '#/definitions/v2.ResumeChangefeedConfig'
  1995        produces:
  1996        - application/json
  1997        responses:
  1998          "200":
  1999            description: OK
  2000            schema:
  2001              $ref: '#/definitions/v2.EmptyResponse'
  2002          "400":
  2003            description: Bad Request
  2004            schema:
  2005              $ref: '#/definitions/model.HTTPError'
  2006          "500":
  2007            description: Internal Server Error
  2008            schema:
  2009              $ref: '#/definitions/model.HTTPError'
  2010        summary: Resume a changefeed
  2011        tags:
  2012        - changefeed
  2013        - v2
  2014    /api/v2/changefeeds/{changefeed_id}/synced:
  2015      get:
  2016        consumes:
  2017        - application/json
  2018        description: get the synced status of a changefeed
  2019        parameters:
  2020        - description: changefeed_id
  2021          in: path
  2022          name: changefeed_id
  2023          required: true
  2024          type: string
  2025        - description: default
  2026          in: query
  2027          name: namespace
  2028          type: string
  2029        produces:
  2030        - application/json
  2031        responses:
  2032          "200":
  2033            description: OK
  2034            schema:
  2035              $ref: '#/definitions/v2.SyncedStatus'
  2036          "400":
  2037            description: Bad Request
  2038            schema:
  2039              $ref: '#/definitions/model.HTTPError'
  2040          "500":
  2041            description: Internal Server Error
  2042            schema:
  2043              $ref: '#/definitions/model.HTTPError'
  2044        summary: Get synced status
  2045        tags:
  2046        - changefeed
  2047        - v2
  2048    /api/v2/health:
  2049      get:
  2050        description: Check the health status of a TiCDC cluster
  2051        produces:
  2052        - application/json
  2053        responses:
  2054          "200":
  2055            description: OK
  2056            schema:
  2057              $ref: '#/definitions/v2.EmptyResponse'
  2058          "400":
  2059            description: Bad Request
  2060            schema:
  2061              $ref: '#/definitions/model.HTTPError'
  2062          "500":
  2063            description: Internal Server Error
  2064            schema:
  2065              $ref: '#/definitions/model.HTTPError'
  2066        summary: Check the health status of a TiCDC cluster
  2067        tags:
  2068        - common
  2069        - v2
  2070    /api/v2/log:
  2071      post:
  2072        consumes:
  2073        - application/json
  2074        description: change TiCDC log level dynamically
  2075        parameters:
  2076        - description: log level
  2077          in: body
  2078          name: log_level
  2079          required: true
  2080          schema:
  2081            $ref: '#/definitions/v2.LogLevelReq'
  2082        produces:
  2083        - application/json
  2084        responses:
  2085          "200":
  2086            description: OK
  2087            schema:
  2088              $ref: '#/definitions/v2.EmptyResponse'
  2089          "400":
  2090            description: Bad Request
  2091            schema:
  2092              $ref: '#/definitions/model.HTTPError'
  2093        summary: Change TiCDC log level
  2094        tags:
  2095        - common
  2096        - v2
  2097    /api/v2/owner/resign:
  2098      post:
  2099        consumes:
  2100        - application/json
  2101        description: Notify the current controller to resign
  2102        produces:
  2103        - application/json
  2104        responses:
  2105          "200":
  2106            description: OK
  2107            schema:
  2108              $ref: '#/definitions/v2.EmptyResponse'
  2109          "400":
  2110            description: Bad Request
  2111            schema:
  2112              $ref: '#/definitions/model.HTTPError'
  2113          "500":
  2114            description: Internal Server Error
  2115            schema:
  2116              $ref: '#/definitions/model.HTTPError'
  2117        summary: Notify the controller to resign
  2118        tags:
  2119        - owner
  2120        - v2
  2121    /api/v2/processors:
  2122      get:
  2123        description: list all processors in the TiCDC cluster
  2124        produces:
  2125        - application/json
  2126        responses:
  2127          "200":
  2128            description: OK
  2129            schema:
  2130              items:
  2131                $ref: '#/definitions/v2.ProcessorCommonInfo'
  2132              type: array
  2133          "400":
  2134            description: Bad Request
  2135            schema:
  2136              $ref: '#/definitions/model.HTTPError'
  2137          "500":
  2138            description: Internal Server Error
  2139            schema:
  2140              $ref: '#/definitions/model.HTTPError'
  2141        summary: List processors
  2142        tags:
  2143        - processor
  2144        - v2
  2145    /api/v2/processors/{changefeed_id}/{capture_id}:
  2146      get:
  2147        description: get the detail information of a processor
  2148        parameters:
  2149        - description: changefeed ID
  2150          in: path
  2151          name: changefeed_id
  2152          required: true
  2153          type: string
  2154        - description: default
  2155          in: query
  2156          name: namespace
  2157          type: string
  2158        - description: capture ID
  2159          in: path
  2160          name: capture_id
  2161          required: true
  2162          type: string
  2163        produces:
  2164        - application/json
  2165        responses:
  2166          "200":
  2167            description: OK
  2168            schema:
  2169              $ref: '#/definitions/v2.ProcessorDetail'
  2170          "400":
  2171            description: Bad Request
  2172            schema:
  2173              $ref: '#/definitions/model.HTTPError'
  2174          "500":
  2175            description: Internal Server Error
  2176            schema:
  2177              $ref: '#/definitions/model.HTTPError'
  2178        summary: Get processor detail information
  2179        tags:
  2180        - processor
  2181        - v2
  2182    /api/v2/status:
  2183      get:
  2184        consumes:
  2185        - application/json
  2186        description: This API is a synchronous interface. If the request is successful,
  2187        produces:
  2188        - application/json
  2189        responses:
  2190          "200":
  2191            description: OK
  2192            schema:
  2193              $ref: '#/definitions/v2.ServerStatus'
  2194          "400":
  2195            description: Bad Request
  2196            schema:
  2197              $ref: '#/definitions/model.HTTPError'
  2198          "500":
  2199            description: Internal Server Error
  2200            schema:
  2201              $ref: '#/definitions/model.HTTPError'
  2202        summary: Get the status information of a TiCDC node
  2203        tags:
  2204        - common
  2205        - v2
  2206  swagger: "2.0"