Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 30 for queue (0.26 sec)

  1. internal/logger/config.go

    	EnvKafkaVersion       = "MINIO_AUDIT_KAFKA_VERSION"
    	EnvKafkaQueueDir      = "MINIO_AUDIT_KAFKA_QUEUE_DIR"
    	EnvKafkaQueueSize     = "MINIO_AUDIT_KAFKA_QUEUE_SIZE"
    
    	loggerTargetNamePrefix = "logger-"
    	auditTargetNamePrefix  = "audit-"
    )
    
    var (
    	errInvalidQueueSize = errors.New("invalid queue_size value")
    	errInvalidBatchSize = errors.New("invalid batch_size value")
    )
    
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Thu Apr 04 12:04:40 GMT 2024
    - 15.8K bytes
    - Viewed (0)
  2. internal/event/target/kafka.go

    	saramatls "github.com/IBM/sarama/tools/tls"
    )
    
    // Kafka input constants
    const (
    	KafkaBrokers          = "brokers"
    	KafkaTopic            = "topic"
    	KafkaQueueDir         = "queue_dir"
    	KafkaQueueLimit       = "queue_limit"
    	KafkaTLS              = "tls"
    	KafkaTLSSkipVerify    = "tls_skip_verify"
    	KafkaTLSClientAuth    = "tls_client_auth"
    	KafkaSASL             = "sasl"
    	KafkaSASLUsername     = "sasl_username"
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Tue Feb 20 08:16:35 GMT 2024
    - 13K bytes
    - Viewed (0)
  3. internal/event/target/nats.go

    	NATSPassword      = "password"
    	NATSToken         = "token"
    	NATSTLS           = "tls"
    	NATSTLSSkipVerify = "tls_skip_verify"
    	NATSPingInterval  = "ping_interval"
    	NATSQueueDir      = "queue_dir"
    	NATSQueueLimit    = "queue_limit"
    	NATSCertAuthority = "cert_authority"
    	NATSClientCert    = "client_cert"
    	NATSClientKey     = "client_key"
    
    	// Streaming constants - deprecated
    	NATSStreaming                   = "streaming"
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Tue Feb 27 18:11:55 GMT 2024
    - 12.8K bytes
    - Viewed (0)
  4. internal/s3select/select.go

    	getProgressFunc := s3Select.getProgress
    	if !s3Select.Progress.Enabled {
    		getProgressFunc = nil
    	}
    	writer := newMessageWriter(w, getProgressFunc)
    
    	var outputQueue []sql.Record
    
    	// Create queue based on the type.
    	if s3Select.statement.IsAggregated() {
    		outputQueue = make([]sql.Record, 0, 1)
    	} else {
    		outputQueue = make([]sql.Record, 0, 100)
    	}
    	var err error
    	sendRecord := func() bool {
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Mon Nov 06 22:26:08 GMT 2023
    - 21K bytes
    - Viewed (0)
  5. internal/event/target/amqp.go

    	QueueLimit        uint64   `json:"queueLimit"`
    }
    
    //lint:file-ignore ST1003 We cannot change these exported names.
    
    // AMQP input constants.
    const (
    	AmqpQueueDir   = "queue_dir"
    	AmqpQueueLimit = "queue_limit"
    
    	AmqpURL               = "url"
    	AmqpExchange          = "exchange"
    	AmqpRoutingKey        = "routing_key"
    	AmqpExchangeType      = "exchange_type"
    	AmqpDeliveryMode      = "delivery_mode"
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Sat Oct 07 15:07:38 GMT 2023
    - 10K bytes
    - Viewed (0)
  6. internal/grid/connection.go

    				return
    			}
    			continue
    		}
    
    		// Merge entries and send
    		queue = append(queue, toSend)
    		if debugPrint {
    			fmt.Println("Merging", len(queue), "messages")
    		}
    
    		toSend = merged[:0]
    		m := message{Op: OpMerged, Seq: uint32(len(queue))}
    		var err error
    		toSend, err = m.MarshalMsg(toSend)
    		if err != nil {
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Thu Apr 04 12:04:40 GMT 2024
    - 42.6K bytes
    - Viewed (0)
  7. internal/event/target/postgresql.go

    	PostgresPort               = "port"
    	PostgresUsername           = "username"
    	PostgresPassword           = "password"
    	PostgresDatabase           = "database"
    	PostgresQueueDir           = "queue_dir"
    	PostgresQueueLimit         = "queue_limit"
    	PostgresMaxOpenConnections = "max_open_connections"
    
    	EnvPostgresEnable             = "MINIO_NOTIFY_POSTGRES_ENABLE"
    	EnvPostgresFormat             = "MINIO_NOTIFY_POSTGRES_FORMAT"
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Wed Apr 24 17:51:07 GMT 2024
    - 13.3K bytes
    - Viewed (0)
  8. internal/logger/target/kafka/kafka.go

    	"github.com/minio/minio/internal/logger/target/types"
    	"github.com/minio/minio/internal/once"
    	"github.com/minio/minio/internal/store"
    	xnet "github.com/minio/pkg/v2/net"
    )
    
    // the suffix for the configured queue dir where the logs will be persisted.
    const kafkaLoggerExtension = ".kafka.log"
    
    const (
    	statusClosed = iota
    	statusOffline
    	statusOnline
    )
    
    // Config - kafka target arguments.
    type Config struct {
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Thu Feb 22 06:26:06 GMT 2024
    - 10.1K bytes
    - Viewed (1)
  9. internal/event/target/elasticsearch.go

    	"github.com/pkg/errors"
    )
    
    // Elastic constants
    const (
    	ElasticFormat     = "format"
    	ElasticURL        = "url"
    	ElasticIndex      = "index"
    	ElasticQueueDir   = "queue_dir"
    	ElasticQueueLimit = "queue_limit"
    	ElasticUsername   = "username"
    	ElasticPassword   = "password"
    
    	EnvElasticEnable     = "MINIO_NOTIFY_ELASTICSEARCH_ENABLE"
    	EnvElasticFormat     = "MINIO_NOTIFY_ELASTICSEARCH_FORMAT"
    Go
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Thu Jan 18 07:03:17 GMT 2024
    - 15K bytes
    - Viewed (0)
  10. docs/metrics/prometheus/list.md

    | `minio_cluster_replication_last_minute_queued_count`       | Total number of objects queued for replication in the last full minute                                   |
    | `minio_cluster_replication_last_minute_queued_bytes`       | Total number of bytes queued for replication in the last full minute                                     |
    Plain Text
    - Registered: Sun May 05 19:28:20 GMT 2024
    - Last Modified: Thu Apr 25 22:01:31 GMT 2024
    - 43.4K bytes
    - Viewed (2)
Back to top