cli

package
v1.2.8 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Mar 1, 2024 License: MIT Imports: 100 Imported by: 3

README

Documentation for the Cadence command line interface is located at our main site.

Build CLI binary locally

To build the CLI tool locally check out the version tag (e.g. git checkout v0.21.3) and run make tools. This produces an executable called cadence.

Run help command with a local build:

./cadence --help

Command to describe a domain would look like this:

./cadence --domain samples-domain domain describe

Documentation

Index

Constants

View Source
const (
	FlagVerbose                           = "verbose"
	FlagUsername                          = "username"
	FlagPassword                          = "password"
	FlagKeyspace                          = "keyspace"
	FlagDatabaseName                      = "db_name"
	FlagEncodingType                      = "encoding_type"
	FlagDecodingTypes                     = "decoding_types"
	FlagAddress                           = "address"
	FlagAddressWithAlias                  = FlagAddress + ", ad"
	FlagDestinationAddress                = "destination_address"
	FlagHistoryAddress                    = "history_address"
	FlagDBType                            = "db_type"
	FlagDBAddress                         = "db_address"
	FlagDBPort                            = "db_port"
	FlagDBRegion                          = "db_region"
	FlagDBShard                           = "db_shard"
	FlagHistoryAddressWithAlias           = FlagHistoryAddress + ", had"
	FlagProtoVersion                      = "protocol_version"
	FlagDomainID                          = "domain_id"
	FlagDomain                            = "domain"
	FlagDestinationDomain                 = "destination_domain"
	FlagDomainWithAlias                   = FlagDomain + ", do"
	FlagShardID                           = "shard_id"
	FlagShardIDWithAlias                  = FlagShardID + ", sid"
	FlagShards                            = "shards"
	FlagRangeID                           = "range_id"
	FlagRangeIDWithAlias                  = FlagRangeID + ", rid"
	FlagWorkflowID                        = "workflow_id"
	FlagWorkflowIDWithAlias               = FlagWorkflowID + ", wid, w"
	FlagRunID                             = "run_id"
	FlagTreeID                            = "tree_id"
	FlagBranchID                          = "branch_id"
	FlagNumberOfShards                    = "number_of_shards"
	FlagRunIDWithAlias                    = FlagRunID + ", rid, r"
	FlagTargetCluster                     = "target_cluster"
	FlagTargetClusterWithAlias            = FlagTargetCluster + ", tc"
	FlagSourceCluster                     = "source_cluster"
	FlagSourceClusterWithAlias            = FlagSourceCluster + ", sc"
	FlagMinEventID                        = "min_event_id"
	FlagMaxEventID                        = "max_event_id"
	FlagEndEventVersion                   = "end_event_version"
	FlagTaskList                          = "tasklist"
	FlagTaskListWithAlias                 = FlagTaskList + ", tl"
	FlagTaskListType                      = "tasklisttype"
	FlagTaskListTypeWithAlias             = FlagTaskListType + ", tlt"
	FlagWorkflowIDReusePolicy             = "workflowidreusepolicy"
	FlagWorkflowIDReusePolicyAlias        = FlagWorkflowIDReusePolicy + ", wrp"
	FlagCronSchedule                      = "cron"
	FlagWorkflowType                      = "workflow_type"
	FlagWorkflowTypeWithAlias             = FlagWorkflowType + ", wt"
	FlagWorkflowStatus                    = "status"
	FlagWorkflowStatusWithAlias           = FlagWorkflowStatus + ", s"
	FlagExecutionTimeout                  = "execution_timeout"
	FlagExecutionTimeoutWithAlias         = FlagExecutionTimeout + ", et"
	FlagDecisionTimeout                   = "decision_timeout"
	FlagDecisionTimeoutWithAlias          = FlagDecisionTimeout + ", dt"
	FlagContextTimeout                    = "context_timeout"
	FlagContextTimeoutWithAlias           = FlagContextTimeout + ", ct"
	FlagInput                             = "input"
	FlagInputWithAlias                    = FlagInput + ", i"
	FlagInputFile                         = "input_file"
	FlagInputFileWithAlias                = FlagInputFile + ", if"
	FlagInputEncoding                     = "encoding"
	FlagInputEncodingWithAlias            = FlagInputEncoding + ", enc"
	FlagSignalInput                       = "signal_input"
	FlagSignalInputWithAlias              = FlagSignalInput + ", si"
	FlagSignalInputFile                   = "signal_input_file"
	FlagSignalInputFileWithAlias          = FlagSignalInputFile + ", sif"
	FlagExcludeFile                       = "exclude_file"
	FlagInputSeparator                    = "input_separator"
	FlagParallelism                       = "input_parallelism"
	FlagParallismDeprecated               = "input_parallism" // typo, replaced by FlagParallelism
	FlagScanType                          = "scan_type"
	FlagInvariantCollection               = "invariant_collection"
	FlagSkipCurrentOpen                   = "skip_current_open"
	FlagSkipCurrentCompleted              = "skip_current_completed"
	FlagSkipBaseIsNotCurrent              = "skip_base_is_not_current"
	FlagDryRun                            = "dry_run"
	FlagNonDeterministicOnly              = "only_non_deterministic"
	FlagInputTopic                        = "input_topic"
	FlagInputTopicWithAlias               = FlagInputTopic + ", it"
	FlagHostFile                          = "host_file"
	FlagCluster                           = "cluster"
	FlagInputCluster                      = "input_cluster"
	FlagStartOffset                       = "start_offset"
	FlagTopic                             = "topic"
	FlagGroup                             = "group"
	FlagResult                            = "result"
	FlagIdentity                          = "identity"
	FlagDetail                            = "detail"
	FlagReason                            = "reason"
	FlagReasonWithAlias                   = FlagReason + ", re"
	FlagOpen                              = "open"
	FlagOpenWithAlias                     = FlagOpen + ", op"
	FlagMore                              = "more"
	FlagMoreWithAlias                     = FlagMore + ", m"
	FlagAll                               = "all"
	FlagPrefix                            = "prefix"
	FlagAllWithAlias                      = FlagAll + ", a"
	FlagDeprecated                        = "deprecated"
	FlagDeprecatedWithAlias               = FlagDeprecated + ", dep"
	FlagForce                             = "force"
	FlagPageID                            = "page_id"
	FlagPageSize                          = "pagesize"
	FlagPageSizeWithAlias                 = FlagPageSize + ", ps"
	FlagEarliestTime                      = "earliest_time"
	FlagEarliestTimeWithAlias             = FlagEarliestTime + ", et"
	FlagLatestTime                        = "latest_time"
	FlagLatestTimeWithAlias               = FlagLatestTime + ", lt"
	FlagPrintEventVersion                 = "print_event_version"
	FlagPrintEventVersionWithAlias        = FlagPrintEventVersion + ", pev"
	FlagPrintFullyDetail                  = "print_full"
	FlagPrintFullyDetailWithAlias         = FlagPrintFullyDetail + ", pf"
	FlagPrintRawTime                      = "print_raw_time"
	FlagPrintRawTimeWithAlias             = FlagPrintRawTime + ", prt"
	FlagPrintRaw                          = "print_raw"
	FlagPrintRawWithAlias                 = FlagPrintRaw + ", praw"
	FlagPrintDateTime                     = "print_datetime"
	FlagPrintDateTimeWithAlias            = FlagPrintDateTime + ", pdt"
	FlagPrintMemo                         = "print_memo"
	FlagPrintMemoWithAlias                = FlagPrintMemo + ", pme"
	FlagPrintSearchAttr                   = "print_search_attr"
	FlagPrintSearchAttrWithAlias          = FlagPrintSearchAttr + ", psa"
	FlagPrintJSON                         = "print_json"              // Deprecated: use --format json
	FlagPrintJSONWithAlias                = FlagPrintJSON + ", pjson" // Deprecated: use --format json
	FlagDescription                       = "description"
	FlagDescriptionWithAlias              = FlagDescription + ", desc"
	FlagOwnerEmail                        = "owner_email"
	FlagOwnerEmailWithAlias               = FlagOwnerEmail + ", oe"
	FlagRetentionDays                     = "retention"
	FlagRetentionDaysWithAlias            = FlagRetentionDays + ", rd"
	FlagHistoryArchivalStatus             = "history_archival_status"
	FlagHistoryArchivalStatusWithAlias    = FlagHistoryArchivalStatus + ", has"
	FlagHistoryArchivalURI                = "history_uri"
	FlagHistoryArchivalURIWithAlias       = FlagHistoryArchivalURI + ", huri"
	FlagVisibilityArchivalStatus          = "visibility_archival_status"
	FlagVisibilityArchivalStatusWithAlias = FlagVisibilityArchivalStatus + ", vas"
	FlagVisibilityArchivalURI             = "visibility_uri"
	FlagVisibilityArchivalURIWithAlias    = FlagVisibilityArchivalURI + ", vuri"
	FlagName                              = "name"
	FlagNameWithAlias                     = FlagName + ", n"
	FlagOutputFilename                    = "output_filename"
	FlagOutputFilenameWithAlias           = FlagOutputFilename + ", of"
	FlagOutputFormat                      = "output"
	FlagQueryType                         = "query_type"
	FlagQueryTypeWithAlias                = FlagQueryType + ", qt"
	FlagQueryRejectCondition              = "query_reject_condition"
	FlagQueryRejectConditionWithAlias     = FlagQueryRejectCondition + ", qrc"
	FlagQueryConsistencyLevel             = "query_consistency_level"
	FlagQueryConsistencyLevelWithAlias    = FlagQueryConsistencyLevel + ", qcl"
	FlagShowDetail                        = "show_detail"
	FlagShowDetailWithAlias               = FlagShowDetail + ", sd"
	FlagActiveClusterName                 = "active_cluster"
	FlagActiveClusterNameWithAlias        = FlagActiveClusterName + ", ac"
	FlagClusters                          = "clusters"
	FlagClustersWithAlias                 = FlagClusters + ", cl"
	FlagIsGlobalDomain                    = "global_domain"
	FlagIsGlobalDomainWithAlias           = FlagIsGlobalDomain + ", gd"
	FlagDomainData                        = "domain_data"
	FlagDomainDataWithAlias               = FlagDomainData + ", dmd"
	FlagEventID                           = "event_id"
	FlagEventIDWithAlias                  = FlagEventID + ", eid"
	FlagActivityID                        = "activity_id"
	FlagActivityIDWithAlias               = FlagActivityID + ", aid"
	FlagMaxFieldLength                    = "max_field_length"
	FlagMaxFieldLengthWithAlias           = FlagMaxFieldLength + ", maxl"
	FlagSecurityToken                     = "security_token"
	FlagSecurityTokenWithAlias            = FlagSecurityToken + ", st"
	FlagSkipErrorMode                     = "skip_errors"
	FlagRemote                            = "remote"
	FlagTimerType                         = "timer_type"
	FlagSkipErrorModeWithAlias            = FlagSkipErrorMode + ", serr"
	FlagHeadersMode                       = "headers"
	FlagHeadersModeWithAlias              = FlagHeadersMode + ", he"
	FlagMessageType                       = "message_type"
	FlagMessageTypeWithAlias              = FlagMessageType + ", mt"
	FlagURL                               = "url"
	FlagIndex                             = "index"
	FlagBatchSize                         = "batch_size"
	FlagBatchSizeWithAlias                = FlagBatchSize + ", bs"
	FlagMemoKey                           = "memo_key"
	FlagMemo                              = "memo"
	FlagMemoFile                          = "memo_file"
	FlagSearchAttributesKey               = "search_attr_key"
	FlagSearchAttributesVal               = "search_attr_value"
	FlagSearchAttributesType              = "search_attr_type"
	FlagAddBadBinary                      = "add_bad_binary"
	FlagRemoveBadBinary                   = "remove_bad_binary"
	FlagResetType                         = "reset_type"
	FlagDecisionOffset                    = "decision_offset"
	FlagResetPointsOnly                   = "reset_points_only"
	FlagResetBadBinaryChecksum            = "reset_bad_binary_checksum"
	FlagSkipSignalReapply                 = "skip_signal_reapply"
	FlagListQuery                         = "query"
	FlagListQueryWithAlias                = FlagListQuery + ", q"
	FlagExcludeWorkflowIDByQuery          = "exclude_query"
	FlagBatchType                         = "batch_type"
	FlagBatchTypeWithAlias                = FlagBatchType + ", bt"
	FlagSignalName                        = "signal_name"
	FlagSignalNameWithAlias               = FlagSignalName + ", sig"
	FlagTaskID                            = "task_id"
	FlagTaskType                          = "task_type"
	FlagTaskVisibilityTimestamp           = "task_timestamp"
	FlagQueueType                         = "queue_type"
	FlagStartingRPS                       = "starting_rps"
	FlagRPS                               = "rps"
	FlagRPSScaleUpSeconds                 = "rps_scale_up_seconds"
	FlagJobID                             = "job_id"
	FlagJobIDWithAlias                    = FlagJobID + ", jid"
	FlagYes                               = "yes"
	FlagServiceConfigDir                  = "service_config_dir"
	FlagServiceConfigDirWithAlias         = FlagServiceConfigDir + ", scd"
	FlagServiceEnv                        = "service_env"
	FlagServiceEnvWithAlias               = FlagServiceEnv + ", se"
	FlagServiceZone                       = "service_zone"
	FlagServiceZoneWithAlias              = FlagServiceZone + ", sz"
	FlagEnableTLS                         = "tls"
	FlagTLSCertPath                       = "tls_cert_path"
	FlagTLSCertPathWithAlias              = FlagTLSCertPath + ", tcp"
	FlagTLSKeyPath                        = "tls_key_path"
	FlagTLSCaPath                         = "tls_ca_path"
	FlagTLSEnableHostVerification         = "tls_enable_host_verification"
	FlagDLQType                           = "dlq_type"
	FlagDLQTypeWithAlias                  = FlagDLQType + ", dt"
	FlagMaxMessageCount                   = "max_message_count"
	FlagMaxMessageCountWithAlias          = FlagMaxMessageCount + ", mmc"
	FlagLastMessageID                     = "last_message_id"
	FlagLastMessageIDWithAlias            = FlagLastMessageID + ", lm"
	FlagConcurrency                       = "concurrency"
	FlagReportRate                        = "report_rate"
	FlagLowerShardBound                   = "lower_shard_bound"
	FlagUpperShardBound                   = "upper_shard_bound"
	FlagInputDirectory                    = "input_directory"
	FlagSkipHistoryChecks                 = "skip_history_checks"
	FlagFailoverType                      = "failover_type"
	FlagFailoverTypeWithAlias             = FlagFailoverType + ", ft"
	FlagFailoverTimeout                   = "failover_timeout_seconds"
	FlagFailoverTimeoutWithAlias          = FlagFailoverTimeout + ", fts"
	FlagActivityHeartBeatTimeout          = "heart_beat_timeout_seconds"
	FlagActivityHeartBeatTimeoutWithAlias = FlagActivityHeartBeatTimeout + ", hbts"
	FlagFailoverWaitTime                  = "failover_wait_time_second"
	FlagFailoverWaitTimeWithAlias         = FlagFailoverWaitTime + ", fwts"
	FlagFailoverBatchSize                 = "failover_batch_size"
	FlagFailoverBatchSizeWithAlias        = FlagFailoverBatchSize + ", fbs"
	FlagFailoverDomains                   = "domains"
	FlagFailoverDrillWaitTime             = "failover_drill_wait_second"
	FlagFailoverDrillWaitTimeWithAlias    = FlagFailoverDrillWaitTime + ", fdws"
	FlagFailoverDrill                     = "failover_drill"
	FlagFailoverDrillWithAlias            = FlagFailoverDrill + ", fd"
	FlagRetryInterval                     = "retry_interval"
	FlagRetryAttempts                     = "retry_attempts"
	FlagRetryExpiration                   = "retry_expiration"
	FlagRetryBackoff                      = "retry_backoff"
	FlagRetryMaxInterval                  = "retry_max_interval"
	FlagHeaderKey                         = "header_key"
	FlagHeaderValue                       = "header_value"
	FlagHeaderFile                        = "header_file"
	FlagStartDate                         = "start_date"
	FlagEndDate                           = "end_date"
	FlagDateFormat                        = "date_format"
	FlagShardMultiplier                   = "shard_multiplier"
	FlagBucketSize                        = "bucket_size"
	DelayStartSeconds                     = "delay_start_seconds"
	JitterStartSeconds                    = "jitter_start_seconds"
	FlagConnectionAttributes              = "conn_attrs"
	FlagJWT                               = "jwt"
	FlagJWTPrivateKey                     = "jwt-private-key"
	FlagJWTPrivateKeyWithAlias            = FlagJWTPrivateKey + ", jwt-pk"
	FlagDynamicConfigName                 = "name"
	FlagDynamicConfigFilter               = "filter"
	FlagDynamicConfigValue                = "value"
	FlagTransport                         = "transport"
	FlagTransportWithAlias                = FlagTransport + ", t"
	FlagFormat                            = "format"
	FlagJSON                              = "json"
	FlagIsolationGroupSetDrains           = "set-drains"
	FlagIsolationGroupsRemoveAllDrains    = "remove-all-drains"
	FlagSearchAttribute                   = "search_attr"
)

Flags used to specify cli command line arguments

View Source
const (
	// CtxKeyJWT is the name of the context key for the JWT
	CtxKeyJWT = ContextKey("ctxKeyJWT")
)

Variables

This section is empty.

Functions

func AdminAddSearchAttribute added in v0.6.0

func AdminAddSearchAttribute(c *cli.Context)

AdminAddSearchAttribute to whitelist search attribute

func AdminCatIndices added in v0.5.3

func AdminCatIndices(c *cli.Context)

AdminCatIndices cat indices for ES cluster

func AdminCloseShard added in v0.15.0

func AdminCloseShard(c *cli.Context)

AdminCloseShard closes shard by shard id

func AdminCountDLQMessages added in v0.25.0

func AdminCountDLQMessages(c *cli.Context)

AdminCountDLQMessages returns info how many and where DLQ messages are queued

func AdminDBClean added in v0.13.0

func AdminDBClean(c *cli.Context)

AdminDBClean is the command to clean up unhealthy executions. Input is a JSON stream provided via STDIN or a file.

func AdminDBDataDecodeThrift added in v0.24.0

func AdminDBDataDecodeThrift(c *cli.Context)

AdminDBDataDecodeThrift is the command to decode thrift binary into JSON

func AdminDBScan added in v0.13.0

func AdminDBScan(c *cli.Context)

AdminDBScan is used to scan over executions in database and detect corruptions.

func AdminDBScanUnsupportedWorkflow added in v0.16.0

func AdminDBScanUnsupportedWorkflow(c *cli.Context)

AdminDBScanUnsupportedWorkflow is to scan DB for unsupported workflow for a new release

func AdminDelete added in v0.9.0

func AdminDelete(c *cli.Context)

AdminDelete used to delete documents from ElasticSearch with input of list result

func AdminDeleteWorkflow added in v0.5.0

func AdminDeleteWorkflow(c *cli.Context)

AdminDeleteWorkflow delete a workflow execution for admin

func AdminDescribeCluster added in v0.11.0

func AdminDescribeCluster(c *cli.Context)

AdminDescribeCluster is used to dump information about the cluster

func AdminDescribeHistoryHost added in v0.3.13

func AdminDescribeHistoryHost(c *cli.Context)

AdminDescribeHistoryHost describes history host

func AdminDescribeQueue added in v0.15.0

func AdminDescribeQueue(c *cli.Context)

AdminDescribeQueue describes task processing queue states

func AdminDescribeShard added in v0.14.0

func AdminDescribeShard(c *cli.Context)

AdminDescribeShard describes shard by shard id

func AdminDescribeShardDistribution added in v0.22.0

func AdminDescribeShardDistribution(c *cli.Context)

AdminDescribeShardDistribution describes shard distribution

func AdminDescribeTaskList added in v0.5.7

func AdminDescribeTaskList(c *cli.Context)

AdminDescribeTaskList displays poller and status information of task list.

func AdminDescribeWorkflow added in v0.3.13

func AdminDescribeWorkflow(c *cli.Context)

AdminDescribeWorkflow describe a new workflow execution for admin

func AdminFailoverAbort added in v0.15.0

func AdminFailoverAbort(c *cli.Context)

AdminFailoverAbort abort a failover workflow

func AdminFailoverList added in v0.15.0

func AdminFailoverList(c *cli.Context)

AdminFailoverList list failover runs

func AdminFailoverPause added in v0.15.0

func AdminFailoverPause(c *cli.Context)

AdminFailoverPause pause failover workflow

func AdminFailoverQuery added in v0.15.0

func AdminFailoverQuery(c *cli.Context)

AdminFailoverQuery query a failover workflow

func AdminFailoverResume added in v0.15.0

func AdminFailoverResume(c *cli.Context)

AdminFailoverResume resume a paused failover workflow

func AdminFailoverRollback added in v0.15.0

func AdminFailoverRollback(c *cli.Context)

AdminFailoverRollback rollback a failover run

func AdminFailoverStart added in v0.15.0

func AdminFailoverStart(c *cli.Context)

AdminFailoverStart start failover workflow

func AdminGetAsyncWFConfig added in v1.2.8

func AdminGetAsyncWFConfig(c *cli.Context)

func AdminGetDLQMessages added in v0.12.0

func AdminGetDLQMessages(c *cli.Context)

AdminGetDLQMessages gets DLQ metadata

func AdminGetDomainIDOrName added in v0.5.0

func AdminGetDomainIDOrName(c *cli.Context)

AdminGetDomainIDOrName map domain

func AdminGetDomainIsolationGroups added in v1.2.1

func AdminGetDomainIsolationGroups(c *cli.Context)

func AdminGetDynamicConfig added in v0.23.1

func AdminGetDynamicConfig(c *cli.Context)

AdminGetDynamicConfig gets value of specified dynamic config parameter matching specified filter

func AdminGetGlobalIsolationGroups added in v1.2.1

func AdminGetGlobalIsolationGroups(c *cli.Context)

func AdminGetShardID added in v0.5.0

func AdminGetShardID(c *cli.Context)

AdminGetShardID get shardID

func AdminIndex added in v0.5.3

func AdminIndex(c *cli.Context)

AdminIndex used to bulk insert message from kafka parse

func AdminKafkaParse added in v0.5.0

func AdminKafkaParse(c *cli.Context)

AdminKafkaParse parses the output of k8read and outputs replication tasks

func AdminListConfigKeys added in v1.0.0

func AdminListConfigKeys(c *cli.Context)

AdminListConfigKeys lists all available dynamic config keys with description and default value

func AdminListDynamicConfig added in v0.23.1

func AdminListDynamicConfig(c *cli.Context)

AdminListDynamicConfig lists all values associated with specified dynamic config parameter or all values for all dc parameter if none is specified.

func AdminListTaskList added in v0.24.0

func AdminListTaskList(c *cli.Context)

AdminListTaskList displays all task lists under a domain.

func AdminMaintainCorruptWorkflow added in v0.24.0

func AdminMaintainCorruptWorkflow(c *cli.Context) error

AdminMaintainCorruptWorkflow deletes workflow from DB if it's corrupt

func AdminMergeDLQMessages added in v0.12.0

func AdminMergeDLQMessages(c *cli.Context)

AdminMergeDLQMessages merges message from DLQ

func AdminPurgeDLQMessages added in v0.12.0

func AdminPurgeDLQMessages(c *cli.Context)

AdminPurgeDLQMessages deletes messages from DLQ

func AdminRebalanceList added in v0.22.0

func AdminRebalanceList(c *cli.Context)

func AdminRebalanceStart added in v0.22.0

func AdminRebalanceStart(c *cli.Context)

func AdminRefreshWorkflowTasks added in v0.12.0

func AdminRefreshWorkflowTasks(c *cli.Context)

AdminRefreshWorkflowTasks refreshes all the tasks of a workflow

func AdminRemoveTask added in v0.9.0

func AdminRemoveTask(c *cli.Context)

AdminRemoveTask describes history host

func AdminRereplicate added in v0.5.0

func AdminRereplicate(c *cli.Context)

AdminRereplicate parses will re-publish replication tasks to topic

func AdminResetQueue added in v0.15.0

func AdminResetQueue(c *cli.Context)

AdminResetQueue resets task processing queue states

func AdminRestoreDynamicConfig added in v0.23.1

func AdminRestoreDynamicConfig(c *cli.Context)

AdminRestoreDynamicConfig removes values of specified dynamic config parameter matching specified filter

func AdminSetShardRangeID added in v0.16.0

func AdminSetShardRangeID(c *cli.Context)

AdminSetShardRangeID set shard rangeID by shard id

func AdminShowWorkflow added in v0.5.0

func AdminShowWorkflow(c *cli.Context)

AdminShowWorkflow shows history

func AdminTimers added in v0.14.0

func AdminTimers(c *cli.Context)

AdminTimers is used to list scheduled timers.

func AdminUpdateAsyncWFConfig added in v1.2.8

func AdminUpdateAsyncWFConfig(c *cli.Context)

func AdminUpdateDomainIsolationGroups added in v1.2.1

func AdminUpdateDomainIsolationGroups(c *cli.Context)

func AdminUpdateDynamicConfig added in v0.23.1

func AdminUpdateDynamicConfig(c *cli.Context)

AdminUpdateDynamicConfig updates specified dynamic config parameter with specified values

func AdminUpdateGlobalIsolationGroups added in v1.2.1

func AdminUpdateGlobalIsolationGroups(c *cli.Context)

func CancelWorkflow

func CancelWorkflow(c *cli.Context)

CancelWorkflow cancels a workflow execution

func ColorEvent added in v0.3.11

func ColorEvent(e *types.HistoryEvent) string

ColorEvent takes an event and return string with color Event with color mapping rules:

Failed - red
Timeout - yellow
Canceled - magenta
Completed - green
Started - blue
Others - default (white/black)

func CompleteActivity added in v0.5.7

func CompleteActivity(c *cli.Context)

CompleteActivity completes an activity

func CountWorkflow added in v0.6.0

func CountWorkflow(c *cli.Context)

CountWorkflow count number of workflows

func DescribeBatchJob added in v0.7.0

func DescribeBatchJob(c *cli.Context)

DescribeBatchJob describe the status of the batch job

func DescribeTaskList

func DescribeTaskList(c *cli.Context)

DescribeTaskList show pollers info of a given tasklist

func DescribeWorkflow added in v0.3.11

func DescribeWorkflow(c *cli.Context)

DescribeWorkflow show information about the specified workflow execution

func DescribeWorkflowWithID added in v0.3.11

func DescribeWorkflowWithID(c *cli.Context)

DescribeWorkflowWithID show information about the specified workflow execution

func ErrorAndExit

func ErrorAndExit(msg string, err error)

ErrorAndExit print easy to understand error msg first then error detail in a new line

func EventColorFunction added in v1.2.1

func EventColorFunction(eventType types.EventType) func(format string, a ...interface{}) string

func FailActivity added in v0.5.7

func FailActivity(c *cli.Context)

FailActivity fails an activity

func GenerateReport added in v0.8.0

func GenerateReport(c *cli.Context)

GenerateReport generate report for an aggregation query to ES

func GetHistory

func GetHistory(ctx context.Context, workflowClient frontend.Client, domain, workflowID, runID string) (*types.History, error)

GetHistory helper method to iterate over all pages and return complete list of history events

func GetSearchAttributes added in v0.5.9

func GetSearchAttributes(c *cli.Context)

GetSearchAttributes get valid search attributes

func GetWorkflowHistoryIterator added in v0.24.0

func GetWorkflowHistoryIterator(
	ctx context.Context,
	workflowClient frontend.Client,
	domain,
	workflowID,
	runID string,
	isLongPoll bool,
	filterType *types.HistoryEventFilterType,
) (pagination.Iterator, error)

GetWorkflowHistoryIterator returns a HistoryEvent iterator

func HistoryEventToString

func HistoryEventToString(e *types.HistoryEvent, printFully bool, maxFieldLength int) string

HistoryEventToString convert HistoryEvent to string

func ListAllWorkflow added in v0.3.11

func ListAllWorkflow(c *cli.Context)

ListAllWorkflow list all workflow executions based on filters

func ListArchivedWorkflow added in v0.9.3

func ListArchivedWorkflow(c *cli.Context)

ListArchivedWorkflow lists archived workflow executions based on filters

func ListBatchJobs added in v0.7.0

func ListBatchJobs(c *cli.Context)

ListBatchJobs list the started batch jobs

func ListTaskListPartitions added in v0.12.0

func ListTaskListPartitions(c *cli.Context)

ListTaskListPartitions gets all the tasklist partition and host information.

func ListWorkflow

func ListWorkflow(c *cli.Context)

ListWorkflow list workflow executions based on filters

func NewCliApp

func NewCliApp() *cli.App

NewCliApp instantiates a new instance of the CLI application.

func ObserveHistory added in v0.3.11

func ObserveHistory(c *cli.Context)

ObserveHistory show the process of running workflow

func ObserveHistoryWithID added in v0.3.11

func ObserveHistoryWithID(c *cli.Context)

ObserveHistoryWithID show the process of running workflow

func QueryWorkflow

func QueryWorkflow(c *cli.Context)

QueryWorkflow query workflow execution

func QueryWorkflowUsingQueryTypes added in v1.2.7

func QueryWorkflowUsingQueryTypes(c *cli.Context)

QueryWorkflowUsingQueryTypes list all query types of the workflow using __query_types as query type

func QueryWorkflowUsingStackTrace

func QueryWorkflowUsingStackTrace(c *cli.Context)

QueryWorkflowUsingStackTrace query workflow execution using __stack_trace as query type

func Render added in v0.24.0

func Render(c *cli.Context, data interface{}, opts RenderOptions) (err error)

Render is an entry point for presentation layer. It uses --format flag to determine output format.

func RenderTable added in v0.24.0

func RenderTable(w io.Writer, data interface{}, opts RenderOptions) error

RenderTable is generic function for rendering a slice of structs as a table

func RenderTemplate added in v0.24.0

func RenderTemplate(w io.Writer, data interface{}, tmpl string, opts RenderOptions) error

RenderTemplate uses golang text/template format to render data with user provided template

func ResetInBatch added in v0.5.8

func ResetInBatch(c *cli.Context)

ResetInBatch resets workflow in batch

func ResetWorkflow added in v0.5.2

func ResetWorkflow(c *cli.Context)

ResetWorkflow reset workflow

func RestartWorkflow added in v0.25.0

func RestartWorkflow(c *cli.Context)

RestartWorkflow restarts a workflow execution

func RunWorkflow

func RunWorkflow(c *cli.Context)

RunWorkflow starts a new workflow execution and print workflow progress and result

func ScanAllWorkflow added in v0.9.0

func ScanAllWorkflow(c *cli.Context)

ScanAllWorkflow list all workflow executions using Scan API. It should be faster than ListAllWorkflow, but result are not sorted.

func SetFactory added in v0.5.0

func SetFactory(factory ClientFactory)

SetFactory is used to set the ClientFactory global

func SetRequiredDomainDataKeys added in v0.3.14

func SetRequiredDomainDataKeys(keys []string)

SetRequiredDomainDataKeys will set requiredDomainDataKeys

func ShowHistory

func ShowHistory(c *cli.Context)

ShowHistory shows the history of given workflow execution based on workflowID and runID.

func ShowHistoryWithWID

func ShowHistoryWithWID(c *cli.Context)

ShowHistoryWithWID shows the history of given workflow with workflow_id

func SignalWithStartWorkflowExecution added in v0.18.0

func SignalWithStartWorkflowExecution(c *cli.Context)

SignalWithStartWorkflowExecution starts a workflow execution if not already exists and signals it

func SignalWorkflow

func SignalWorkflow(c *cli.Context)

SignalWorkflow signals a workflow execution

func StartBatchJob added in v0.7.0

func StartBatchJob(c *cli.Context)

StartBatchJob starts a batch job

func StartWorkflow

func StartWorkflow(c *cli.Context)

StartWorkflow starts a new workflow execution

func TerminateBatchJob added in v0.7.0

func TerminateBatchJob(c *cli.Context)

TerminateBatchJob stops abatch job

func TerminateWorkflow

func TerminateWorkflow(c *cli.Context)

TerminateWorkflow terminates a workflow execution

Types

type AutoResetPointRow added in v0.24.0

type AutoResetPointRow struct {
	BinaryChecksum string    `header:"Binary Checksum"`
	CreateTime     time.Time `header:"Create Time"`
	RunID          string    `header:"RunID"`
	EventID        int64     `header:"EventID"`
}

type BadBinaryRow added in v0.24.0

type BadBinaryRow struct {
	Checksum  string    `header:"Binary Checksum"`
	Operator  string    `header:"Operator"`
	StartTime time.Time `header:"Start Time"`
	Reason    string    `header:"Reason"`
}

type ClientFactory added in v0.5.0

type ClientFactory interface {
	ServerFrontendClient(c *cli.Context) frontend.Client
	ServerAdminClient(c *cli.Context) admin.Client

	// ServerFrontendClientForMigration frontend client of the migration destination
	ServerFrontendClientForMigration(c *cli.Context) frontend.Client
	// ServerAdminClientForMigration admin client of the migration destination
	ServerAdminClientForMigration(c *cli.Context) admin.Client

	ElasticSearchClient(c *cli.Context) *elastic.Client

	ServerConfig(c *cli.Context) (*config.Config, error)
}

ClientFactory is used to construct rpc clients

func NewClientFactory added in v0.5.0

func NewClientFactory() ClientFactory

NewClientFactory creates a new ClientFactory

type ClustersConfig added in v0.5.0

type ClustersConfig struct {
	Clusters map[string]config.ClusterConfig
	TLS      config.TLS
}

ClustersConfig describes the kafka clusters

type ContextKey added in v0.23.1

type ContextKey string

ContextKey is an alias for string, used as context key

type DLQRow added in v0.24.0

type DLQRow struct {
	ShardID         int                        `header:"Shard ID" json:"shardID"`
	DomainName      string                     `header:"Domain Name" json:"domainName"`
	DomainID        string                     `header:"Domain ID" json:"domainID"`
	WorkflowID      string                     `header:"Workflow ID" json:"workflowID"`
	RunID           string                     `header:"Run ID" json:"runID"`
	TaskID          int64                      `header:"Task ID" json:"taskID"`
	TaskType        *types.ReplicationTaskType `header:"Task Type" json:"taskType"`
	Version         int64                      `json:"version"`
	FirstEventID    int64                      `json:"firstEventID"`
	NextEventID     int64                      `json:"nextEventID"`
	ScheduledID     int64                      `json:"scheduledID"`
	ReplicationTask *types.ReplicationTask     `json:"replicationTask"`

	// Those are deserialized variants from history replications task
	Events       []*types.HistoryEvent `json:"events"`
	NewRunEvents []*types.HistoryEvent `json:"newRunEvents,omitempty"`

	// Only event IDs for compact table representation
	EventIDs       []int64 `header:"Event IDs"`
	NewRunEventIDs []int64 `header:"New Run Event IDs"`
}

type DomainMigrationCommand added in v1.2.5

type DomainMigrationCommand interface {
	Validation(c *cli.Context)
	DomainMetaDataCheck(c *cli.Context) DomainMigrationRow
	DomainWorkFlowCheck(c *cli.Context) DomainMigrationRow
	SearchAttributesChecker(c *cli.Context) DomainMigrationRow
	DynamicConfigCheck(c *cli.Context) DomainMigrationRow
}

func NewDomainMigrationCommand added in v1.2.5

func NewDomainMigrationCommand(c *cli.Context) DomainMigrationCommand

Export a function to create an instance of the domainMigrationCLIImpl.

type DomainMigrationRow added in v1.2.1

type DomainMigrationRow struct {
	ValidationCheck   string `header: "Validation Checker"`
	ValidationResult  bool   `header: "Validation Result"`
	ValidationDetails ValidationDetails
}

type DomainRow added in v0.24.0

type DomainRow struct {
	Name                     string `header:"Name"`
	UUID                     string `header:"UUID"`
	Description              string
	OwnerEmail               string
	DomainData               map[string]string  `header:"Domain Data"`
	Status                   types.DomainStatus `header:"Status"`
	IsGlobal                 bool               `header:"Is Global Domain"`
	ActiveCluster            string             `header:"Active Cluster"`
	Clusters                 []string           `header:"Clusters"`
	RetentionDays            int32              `header:"Retention Days"`
	EmitMetrics              bool
	HistoryArchivalStatus    types.ArchivalStatus `header:"History Archival Status"`
	HistoryArchivalURI       string               `header:"History Archival URI"`
	VisibilityArchivalStatus types.ArchivalStatus `header:"Visibility Archival Status"`
	VisibilityArchivalURI    string               `header:"Visibility Archival URI"`
	BadBinaries              []BadBinaryRow
	FailoverInfo             *FailoverInfoRow
	LongRunningWorkFlowNum   *int
}

type ESIndexRow added in v0.24.0

type ESIndexRow struct {
	Health             string `header:"Health"`
	Status             string `header:"Status"`
	Index              string `header:"Index"`
	PrimaryShards      int    `header:"Pri"`
	ReplicaShards      int    `header:"Rep"`
	DocsCount          int    `header:"Docs Count"`
	DocsDeleted        int    `header:"Docs Deleted"`
	StorageSize        string `header:"Store Size"`
	PrimaryStorageSize string `header:"Pri Store Size"`
}

type FailoverInfoRow added in v0.24.0

type FailoverInfoRow struct {
	FailoverVersion     int64     `header:"Failover Version"`
	StartTime           time.Time `header:"Start Time"`
	ExpireTime          time.Time `header:"Expire Time"`
	CompletedShardCount int32     `header:"Completed Shard Count"`
	PendingShard        []int32   `header:"Pending Shard"`
}

type Histogram added in v0.14.0

type Histogram struct {
	// contains filtered or unexported fields
}

Histogram holds the occurrence count for each key

func NewHistogram added in v0.14.0

func NewHistogram() *Histogram

NewHistogram creates a new Histogram

func (*Histogram) Add added in v0.14.0

func (h *Histogram) Add(key string)

Add will increment occurrence count of the key

func (*Histogram) Len added in v0.14.0

func (h *Histogram) Len() int

func (*Histogram) Less added in v0.14.0

func (h *Histogram) Less(i, j int) bool

func (*Histogram) Print added in v0.14.0

func (h *Histogram) Print(multiplier int) error

Print will output histogram with key and counter information.

func (*Histogram) Swap added in v0.14.0

func (h *Histogram) Swap(i, j int)

type HistoryDLQCountRow added in v0.25.0

type HistoryDLQCountRow struct {
	SourceCluster string `header:"Source Cluster" json:"sourceCluster"`
	ShardID       int32  `header:"Shard ID" json:"shardID"`
	Count         int64  `header:"Count" json:"count"`
}

type JSONHistorySerializer

type JSONHistorySerializer struct{}

JSONHistorySerializer is used to encode history event in JSON

func (*JSONHistorySerializer) Deserialize

func (j *JSONHistorySerializer) Deserialize(data []byte) (*types.History, error)

Deserialize deserializes history

func (*JSONHistorySerializer) Serialize

func (j *JSONHistorySerializer) Serialize(h *types.History) ([]byte, error)

Serialize serializes history.

type LoadCloser added in v0.22.0

type LoadCloser interface {
	Load() []*persistence.TimerTaskInfo
	Close()
}

LoadCloser loads timer task information

func NewDBLoadCloser added in v0.22.0

func NewDBLoadCloser(c *cli.Context) LoadCloser

NewDBLoadCloser creates a new LoadCloser to load timer task information from database

func NewFileLoadCloser added in v0.22.0

func NewFileLoadCloser(c *cli.Context) LoadCloser

NewFileLoadCloser creates a new LoadCloser to load timer task information from file

type MismatchedDynamicConfig added in v1.2.1

type MismatchedDynamicConfig struct {
	Key        dynamicconfig.Key
	CurrValues []*types.DynamicConfigValue
	NewValues  []*types.DynamicConfigValue
}

type Printer added in v0.14.0

type Printer interface {
	Print(timers []*persistence.TimerTaskInfo) error
}

Printer prints timer task information

func NewHistogramPrinter added in v0.14.0

func NewHistogramPrinter(c *cli.Context, timeFormat string) Printer

NewHistogramPrinter creates a new Printer to display timer task information in a histogram

func NewJSONPrinter added in v0.14.0

func NewJSONPrinter(c *cli.Context) Printer

NewJSONPrinter creates a new Printer to display timer task information in a JSON format

type RenderOptions added in v0.24.0

type RenderOptions struct {
	// OptionalColumns may contain column header names which can be hidden
	OptionalColumns map[string]bool

	// Border specified whether to render table border
	Border bool

	// Custom, per column alignment
	ColumnAlignment []int

	// Color will use coloring characters while printing table
	Color bool

	// PrintRawTime will print time as int64 unix nanos
	PrintRawTime bool
	// PrintDateTime will print both date & time
	PrintDateTime bool

	// DefaultTemplate (if specified) will be used to render data when not --format flag is given
	DefaultTemplate string
}

RenderOptions allows passing optional flags for altering rendered table

type Reporter added in v0.14.0

type Reporter struct {
	// contains filtered or unexported fields
}

Reporter wraps LoadCloser, Printer and a filter on time task type and domainID

func NewReporter added in v0.14.0

func NewReporter(domain string, timerTypes []int, loader LoadCloser, printer Printer) *Reporter

NewReporter creates a new Reporter

func (*Reporter) Report added in v0.14.0

func (r *Reporter) Report() error

Report loads, filters and prints timer tasks

type SearchAttributesRow added in v0.24.0

type SearchAttributesRow struct {
	Key       string `header:"Key"`
	ValueType string `header:"Value type"`
}

type SearchAttributesTable added in v0.24.0

type SearchAttributesTable []SearchAttributesRow

func (SearchAttributesTable) Len added in v0.24.0

func (s SearchAttributesTable) Len() int

func (SearchAttributesTable) Less added in v0.24.0

func (s SearchAttributesTable) Less(i, j int) bool

func (SearchAttributesTable) Swap added in v0.24.0

func (s SearchAttributesTable) Swap(i, j int)

type ShardRow added in v0.24.0

type ShardRow struct {
	ShardID  int32  `header:"ShardID"`
	Identity string `header:"Identity"`
}

type TaskListPartitionRow added in v0.24.0

type TaskListPartitionRow struct {
	ActivityPartition string `header:"Activity Task List Partition"`
	DecisionPartition string `header:"Decision Task List Partition"`
	Host              string `header:"Host"`
}

type TaskListPollerRow added in v0.24.0

type TaskListPollerRow struct {
	ActivityIdentity string    `header:"Activity Poller Identity"`
	DecisionIdentity string    `header:"Decision Poller Identity"`
	LastAccessTime   time.Time `header:"Last Access Time"`
}

type TaskListRow added in v0.24.0

type TaskListRow struct {
	Name        string `header:"Task List Name"`
	Type        string `header:"Type"`
	PollerCount int    `header:"Poller Count"`
}

type TaskListStatusRow added in v0.24.0

type TaskListStatusRow struct {
	ReadLevel int64 `header:"Read Level"`
	AckLevel  int64 `header:"Ack Level"`
	Backlog   int64 `header:"Backlog"`
	StartID   int64 `header:"Lease Start TaskID"`
	EndID     int64 `header:"Lease End TaskID"`
}

type ValidationDetails added in v1.2.1

type ValidationDetails struct {
	CurrentDomainRow            *types.DescribeDomainResponse
	NewDomainRow                *types.DescribeDomainResponse
	MismatchedDomainMetaData    string
	LongRunningWorkFlowNum      *int
	MismatchedDynamicConfig     []MismatchedDynamicConfig
	MissingCurrSearchAttributes []string
	MissingNewSearchAttributes  []string
}

type WorkflowRow added in v0.24.0

type WorkflowRow struct {
	WorkflowType     string                 `header:"Workflow Type" maxLength:"32"`
	WorkflowID       string                 `header:"Workflow ID"`
	RunID            string                 `header:"Run ID"`
	TaskList         string                 `header:"Task List"`
	IsCron           bool                   `header:"Is Cron"`
	StartTime        time.Time              `header:"Start Time"`
	ExecutionTime    time.Time              `header:"Execution Time"`
	EndTime          time.Time              `header:"End Time"`
	CloseStatus      string                 `header:"Close Status"`
	HistoryLength    int64                  `header:"History Length"`
	UpdateTime       time.Time              `header:"Update Time"`
	Memo             map[string]string      `header:"Memo"`
	SearchAttributes map[string]interface{} `header:"Search Attributes"`
}

WorkflowRow is a presentation layer entity use to render a table of workflows

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL