mock_kafkacommon

package
v0.0.0-...-22c2ce1 Latest Latest
Warning

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

Go to latest
Published: May 2, 2024 License: MIT Imports: 6 Imported by: 0

Documentation

Overview

Package mock_kafkacommon is a generated GoMock package.

Package mock_kafkacommon is a generated GoMock package.

Package mock_kafkacommon is a generated GoMock package.

Package mock_kafkacommon is a generated GoMock package.

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type MockConsumer

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

MockConsumer is a mock of Consumer interface.

func NewMockConsumer

func NewMockConsumer(ctrl *gomock.Controller) *MockConsumer

NewMockConsumer creates a new mock instance.

func (*MockConsumer) Assign

func (m *MockConsumer) Assign(partitions []kafka.TopicPartition) error

Assign mocks base method.

func (*MockConsumer) Assignment

func (m *MockConsumer) Assignment() ([]kafka.TopicPartition, error)

Assignment mocks base method.

func (*MockConsumer) AssignmentLost

func (m *MockConsumer) AssignmentLost() bool

AssignmentLost mocks base method.

func (*MockConsumer) Close

func (m *MockConsumer) Close() error

Close mocks base method.

func (*MockConsumer) Commit

func (m *MockConsumer) Commit() ([]kafka.TopicPartition, error)

Commit mocks base method.

func (*MockConsumer) CommitMessage

func (m_2 *MockConsumer) CommitMessage(m *kafka.Message) ([]kafka.TopicPartition, error)

CommitMessage mocks base method.

func (*MockConsumer) CommitOffsets

func (m *MockConsumer) CommitOffsets(offsets []kafka.TopicPartition) ([]kafka.TopicPartition, error)

CommitOffsets mocks base method.

func (*MockConsumer) Committed

func (m *MockConsumer) Committed(partitions []kafka.TopicPartition, timeoutMs int) ([]kafka.TopicPartition, error)

Committed mocks base method.

func (*MockConsumer) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockConsumer) Events

func (m *MockConsumer) Events() chan kafka.Event

Events mocks base method.

func (*MockConsumer) GetConsumerGroupMetadata

func (m *MockConsumer) GetConsumerGroupMetadata() (*kafka.ConsumerGroupMetadata, error)

GetConsumerGroupMetadata mocks base method.

func (*MockConsumer) GetMetadata

func (m *MockConsumer) GetMetadata(topic *string, allTopics bool, timeoutMs int) (*kafka.Metadata, error)

GetMetadata mocks base method.

func (*MockConsumer) GetRebalanceProtocol

func (m *MockConsumer) GetRebalanceProtocol() string

GetRebalanceProtocol mocks base method.

func (*MockConsumer) GetWatermarkOffsets

func (m *MockConsumer) GetWatermarkOffsets(topic string, partition int32) (int64, int64, error)

GetWatermarkOffsets mocks base method.

func (*MockConsumer) IncrementalAssign

func (m *MockConsumer) IncrementalAssign(partitions []kafka.TopicPartition) error

IncrementalAssign mocks base method.

func (*MockConsumer) IncrementalUnassign

func (m *MockConsumer) IncrementalUnassign(partitions []kafka.TopicPartition) error

IncrementalUnassign mocks base method.

func (*MockConsumer) OffsetsForTimes

func (m *MockConsumer) OffsetsForTimes(times []kafka.TopicPartition, timeoutMs int) ([]kafka.TopicPartition, error)

OffsetsForTimes mocks base method.

func (*MockConsumer) Pause

func (m *MockConsumer) Pause(partitions []kafka.TopicPartition) error

Pause mocks base method.

func (*MockConsumer) Poll

func (m *MockConsumer) Poll(timeoutMs int) kafka.Event

Poll mocks base method.

func (*MockConsumer) Position

func (m *MockConsumer) Position(partitions []kafka.TopicPartition) ([]kafka.TopicPartition, error)

Position mocks base method.

func (*MockConsumer) QueryWatermarkOffsets

func (m *MockConsumer) QueryWatermarkOffsets(topic string, partition int32, timeoutMs int) (int64, int64, error)

QueryWatermarkOffsets mocks base method.

func (*MockConsumer) ReadMessage

func (m *MockConsumer) ReadMessage(timeout time.Duration) (*kafka.Message, error)

ReadMessage mocks base method.

func (*MockConsumer) Resume

func (m *MockConsumer) Resume(partitions []kafka.TopicPartition) error

Resume mocks base method.

func (*MockConsumer) Seek

func (m *MockConsumer) Seek(partition kafka.TopicPartition, timeoutMs int) error

Seek mocks base method.

func (*MockConsumer) SetOAuthBearerToken

func (m *MockConsumer) SetOAuthBearerToken(oauthBearerToken kafka.OAuthBearerToken) error

SetOAuthBearerToken mocks base method.

func (*MockConsumer) SetOAuthBearerTokenFailure

func (m *MockConsumer) SetOAuthBearerTokenFailure(errstr string) error

SetOAuthBearerTokenFailure mocks base method.

func (*MockConsumer) StoreMessage

func (m_2 *MockConsumer) StoreMessage(m *kafka.Message) ([]kafka.TopicPartition, error)

StoreMessage mocks base method.

func (*MockConsumer) StoreOffsets

func (m *MockConsumer) StoreOffsets(offsets []kafka.TopicPartition) ([]kafka.TopicPartition, error)

StoreOffsets mocks base method.

func (*MockConsumer) String

func (m *MockConsumer) String() string

String mocks base method.

func (*MockConsumer) Subscribe

func (m *MockConsumer) Subscribe(topic string, rebalanceCb kafka.RebalanceCb) error

Subscribe mocks base method.

func (*MockConsumer) SubscribeTopics

func (m *MockConsumer) SubscribeTopics(topics []string, rebalanceCb kafka.RebalanceCb) error

SubscribeTopics mocks base method.

func (*MockConsumer) Subscription

func (m *MockConsumer) Subscription() ([]string, error)

Subscription mocks base method.

func (*MockConsumer) Unassign

func (m *MockConsumer) Unassign() error

Unassign mocks base method.

func (*MockConsumer) Unsubscribe

func (m *MockConsumer) Unsubscribe() error

Unsubscribe mocks base method.

type MockConsumerMockRecorder

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

MockConsumerMockRecorder is the mock recorder for MockConsumer.

func (*MockConsumerMockRecorder) Assign

func (mr *MockConsumerMockRecorder) Assign(partitions interface{}) *gomock.Call

Assign indicates an expected call of Assign.

func (*MockConsumerMockRecorder) Assignment

func (mr *MockConsumerMockRecorder) Assignment() *gomock.Call

Assignment indicates an expected call of Assignment.

func (*MockConsumerMockRecorder) AssignmentLost

func (mr *MockConsumerMockRecorder) AssignmentLost() *gomock.Call

AssignmentLost indicates an expected call of AssignmentLost.

func (*MockConsumerMockRecorder) Close

func (mr *MockConsumerMockRecorder) Close() *gomock.Call

Close indicates an expected call of Close.

func (*MockConsumerMockRecorder) Commit

func (mr *MockConsumerMockRecorder) Commit() *gomock.Call

Commit indicates an expected call of Commit.

func (*MockConsumerMockRecorder) CommitMessage

func (mr *MockConsumerMockRecorder) CommitMessage(m interface{}) *gomock.Call

CommitMessage indicates an expected call of CommitMessage.

func (*MockConsumerMockRecorder) CommitOffsets

func (mr *MockConsumerMockRecorder) CommitOffsets(offsets interface{}) *gomock.Call

CommitOffsets indicates an expected call of CommitOffsets.

func (*MockConsumerMockRecorder) Committed

func (mr *MockConsumerMockRecorder) Committed(partitions, timeoutMs interface{}) *gomock.Call

Committed indicates an expected call of Committed.

func (*MockConsumerMockRecorder) Events

func (mr *MockConsumerMockRecorder) Events() *gomock.Call

Events indicates an expected call of Events.

func (*MockConsumerMockRecorder) GetConsumerGroupMetadata

func (mr *MockConsumerMockRecorder) GetConsumerGroupMetadata() *gomock.Call

GetConsumerGroupMetadata indicates an expected call of GetConsumerGroupMetadata.

func (*MockConsumerMockRecorder) GetMetadata

func (mr *MockConsumerMockRecorder) GetMetadata(topic, allTopics, timeoutMs interface{}) *gomock.Call

GetMetadata indicates an expected call of GetMetadata.

func (*MockConsumerMockRecorder) GetRebalanceProtocol

func (mr *MockConsumerMockRecorder) GetRebalanceProtocol() *gomock.Call

GetRebalanceProtocol indicates an expected call of GetRebalanceProtocol.

func (*MockConsumerMockRecorder) GetWatermarkOffsets

func (mr *MockConsumerMockRecorder) GetWatermarkOffsets(topic, partition interface{}) *gomock.Call

GetWatermarkOffsets indicates an expected call of GetWatermarkOffsets.

func (*MockConsumerMockRecorder) IncrementalAssign

func (mr *MockConsumerMockRecorder) IncrementalAssign(partitions interface{}) *gomock.Call

IncrementalAssign indicates an expected call of IncrementalAssign.

func (*MockConsumerMockRecorder) IncrementalUnassign

func (mr *MockConsumerMockRecorder) IncrementalUnassign(partitions interface{}) *gomock.Call

IncrementalUnassign indicates an expected call of IncrementalUnassign.

func (*MockConsumerMockRecorder) OffsetsForTimes

func (mr *MockConsumerMockRecorder) OffsetsForTimes(times, timeoutMs interface{}) *gomock.Call

OffsetsForTimes indicates an expected call of OffsetsForTimes.

func (*MockConsumerMockRecorder) Pause

func (mr *MockConsumerMockRecorder) Pause(partitions interface{}) *gomock.Call

Pause indicates an expected call of Pause.

func (*MockConsumerMockRecorder) Poll

func (mr *MockConsumerMockRecorder) Poll(timeoutMs interface{}) *gomock.Call

Poll indicates an expected call of Poll.

func (*MockConsumerMockRecorder) Position

func (mr *MockConsumerMockRecorder) Position(partitions interface{}) *gomock.Call

Position indicates an expected call of Position.

func (*MockConsumerMockRecorder) QueryWatermarkOffsets

func (mr *MockConsumerMockRecorder) QueryWatermarkOffsets(topic, partition, timeoutMs interface{}) *gomock.Call

QueryWatermarkOffsets indicates an expected call of QueryWatermarkOffsets.

func (*MockConsumerMockRecorder) ReadMessage

func (mr *MockConsumerMockRecorder) ReadMessage(timeout interface{}) *gomock.Call

ReadMessage indicates an expected call of ReadMessage.

func (*MockConsumerMockRecorder) Resume

func (mr *MockConsumerMockRecorder) Resume(partitions interface{}) *gomock.Call

Resume indicates an expected call of Resume.

func (*MockConsumerMockRecorder) Seek

func (mr *MockConsumerMockRecorder) Seek(partition, timeoutMs interface{}) *gomock.Call

Seek indicates an expected call of Seek.

func (*MockConsumerMockRecorder) SetOAuthBearerToken

func (mr *MockConsumerMockRecorder) SetOAuthBearerToken(oauthBearerToken interface{}) *gomock.Call

SetOAuthBearerToken indicates an expected call of SetOAuthBearerToken.

func (*MockConsumerMockRecorder) SetOAuthBearerTokenFailure

func (mr *MockConsumerMockRecorder) SetOAuthBearerTokenFailure(errstr interface{}) *gomock.Call

SetOAuthBearerTokenFailure indicates an expected call of SetOAuthBearerTokenFailure.

func (*MockConsumerMockRecorder) StoreMessage

func (mr *MockConsumerMockRecorder) StoreMessage(m interface{}) *gomock.Call

StoreMessage indicates an expected call of StoreMessage.

func (*MockConsumerMockRecorder) StoreOffsets

func (mr *MockConsumerMockRecorder) StoreOffsets(offsets interface{}) *gomock.Call

StoreOffsets indicates an expected call of StoreOffsets.

func (*MockConsumerMockRecorder) String

func (mr *MockConsumerMockRecorder) String() *gomock.Call

String indicates an expected call of String.

func (*MockConsumerMockRecorder) Subscribe

func (mr *MockConsumerMockRecorder) Subscribe(topic, rebalanceCb interface{}) *gomock.Call

Subscribe indicates an expected call of Subscribe.

func (*MockConsumerMockRecorder) SubscribeTopics

func (mr *MockConsumerMockRecorder) SubscribeTopics(topics, rebalanceCb interface{}) *gomock.Call

SubscribeTopics indicates an expected call of SubscribeTopics.

func (*MockConsumerMockRecorder) Subscription

func (mr *MockConsumerMockRecorder) Subscription() *gomock.Call

Subscription indicates an expected call of Subscription.

func (*MockConsumerMockRecorder) Unassign

func (mr *MockConsumerMockRecorder) Unassign() *gomock.Call

Unassign indicates an expected call of Unassign.

func (*MockConsumerMockRecorder) Unsubscribe

func (mr *MockConsumerMockRecorder) Unsubscribe() *gomock.Call

Unsubscribe indicates an expected call of Unsubscribe.

type MockConsumerServiceInterface

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

MockConsumerServiceInterface is a mock of ConsumerServiceInterface interface.

func NewMockConsumerServiceInterface

func NewMockConsumerServiceInterface(ctrl *gomock.Controller) *MockConsumerServiceInterface

NewMockConsumerServiceInterface creates a new mock instance.

func (*MockConsumerServiceInterface) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockConsumerServiceInterface) GetConsumer

func (m *MockConsumerServiceInterface) GetConsumer(groupID string) (kafkacommon.Consumer, error)

GetConsumer mocks base method.

type MockConsumerServiceInterfaceMockRecorder

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

MockConsumerServiceInterfaceMockRecorder is the mock recorder for MockConsumerServiceInterface.

func (*MockConsumerServiceInterfaceMockRecorder) GetConsumer

func (mr *MockConsumerServiceInterfaceMockRecorder) GetConsumer(groupID interface{}) *gomock.Call

GetConsumer indicates an expected call of GetConsumer.

type MockKafkaConfigMapServiceInterface

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

MockKafkaConfigMapServiceInterface is a mock of KafkaConfigMapServiceInterface interface

func NewMockKafkaConfigMapServiceInterface

func NewMockKafkaConfigMapServiceInterface(ctrl *gomock.Controller) *MockKafkaConfigMapServiceInterface

NewMockKafkaConfigMapServiceInterface creates a new mock instance

func (*MockKafkaConfigMapServiceInterface) EXPECT

EXPECT returns an object that allows the caller to indicate expected use

func (*MockKafkaConfigMapServiceInterface) GetKafkaConsumerConfigMap

func (m *MockKafkaConfigMapServiceInterface) GetKafkaConsumerConfigMap(consumerGroup string) kafka.ConfigMap

GetKafkaConsumerConfigMap mocks base method

func (*MockKafkaConfigMapServiceInterface) GetKafkaProducerConfigMap

func (m *MockKafkaConfigMapServiceInterface) GetKafkaProducerConfigMap() kafka.ConfigMap

GetKafkaProducerConfigMap mocks base method

type MockKafkaConfigMapServiceInterfaceMockRecorder

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

MockKafkaConfigMapServiceInterfaceMockRecorder is the mock recorder for MockKafkaConfigMapServiceInterface

func (*MockKafkaConfigMapServiceInterfaceMockRecorder) GetKafkaConsumerConfigMap

func (mr *MockKafkaConfigMapServiceInterfaceMockRecorder) GetKafkaConsumerConfigMap(consumerGroup interface{}) *gomock.Call

GetKafkaConsumerConfigMap indicates an expected call of GetKafkaConsumerConfigMap

func (*MockKafkaConfigMapServiceInterfaceMockRecorder) GetKafkaProducerConfigMap

func (mr *MockKafkaConfigMapServiceInterfaceMockRecorder) GetKafkaProducerConfigMap() *gomock.Call

GetKafkaProducerConfigMap indicates an expected call of GetKafkaProducerConfigMap

type MockProducer

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

MockProducer is a mock of Producer interface

func NewMockProducer

func NewMockProducer(ctrl *gomock.Controller) *MockProducer

NewMockProducer creates a new mock instance

func (*MockProducer) Close

func (m *MockProducer) Close()

Close mocks base method

func (*MockProducer) EXPECT

EXPECT returns an object that allows the caller to indicate expected use

func (*MockProducer) Events

func (m *MockProducer) Events() chan kafka.Event

Events mocks base method

func (*MockProducer) Flush

func (m *MockProducer) Flush(timeoutMs int) int

Flush mocks base method

func (*MockProducer) GetFatalError

func (m *MockProducer) GetFatalError() error

GetFatalError mocks base method

func (*MockProducer) GetMetadata

func (m *MockProducer) GetMetadata(topic *string, allTopics bool, timeoutMs int) (*kafka.Metadata, error)

GetMetadata mocks base method

func (*MockProducer) Len

func (m *MockProducer) Len() int

Len mocks base method

func (*MockProducer) OffsetsForTimes

func (m *MockProducer) OffsetsForTimes(times []kafka.TopicPartition, timeoutMs int) ([]kafka.TopicPartition, error)

OffsetsForTimes mocks base method

func (*MockProducer) Produce

func (m *MockProducer) Produce(msg *kafka.Message, deliveryChan chan kafka.Event) error

Produce mocks base method

func (*MockProducer) ProduceChannel

func (m *MockProducer) ProduceChannel() chan *kafka.Message

ProduceChannel mocks base method

func (*MockProducer) QueryWatermarkOffsets

func (m *MockProducer) QueryWatermarkOffsets(topic string, partition int32, timeoutMs int) (int64, int64, error)

QueryWatermarkOffsets mocks base method

func (*MockProducer) SetOAuthBearerToken

func (m *MockProducer) SetOAuthBearerToken(oauthBearerToken kafka.OAuthBearerToken) error

SetOAuthBearerToken mocks base method

func (*MockProducer) SetOAuthBearerTokenFailure

func (m *MockProducer) SetOAuthBearerTokenFailure(errstr string) error

SetOAuthBearerTokenFailure mocks base method

func (*MockProducer) String

func (m *MockProducer) String() string

String mocks base method

func (*MockProducer) TestFatalError

func (m *MockProducer) TestFatalError(code kafka.ErrorCode, str string) kafka.ErrorCode

TestFatalError mocks base method

type MockProducerMockRecorder

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

MockProducerMockRecorder is the mock recorder for MockProducer

func (*MockProducerMockRecorder) Close

func (mr *MockProducerMockRecorder) Close() *gomock.Call

Close indicates an expected call of Close

func (*MockProducerMockRecorder) Events

func (mr *MockProducerMockRecorder) Events() *gomock.Call

Events indicates an expected call of Events

func (*MockProducerMockRecorder) Flush

func (mr *MockProducerMockRecorder) Flush(timeoutMs interface{}) *gomock.Call

Flush indicates an expected call of Flush

func (*MockProducerMockRecorder) GetFatalError

func (mr *MockProducerMockRecorder) GetFatalError() *gomock.Call

GetFatalError indicates an expected call of GetFatalError

func (*MockProducerMockRecorder) GetMetadata

func (mr *MockProducerMockRecorder) GetMetadata(topic, allTopics, timeoutMs interface{}) *gomock.Call

GetMetadata indicates an expected call of GetMetadata

func (*MockProducerMockRecorder) Len

Len indicates an expected call of Len

func (*MockProducerMockRecorder) OffsetsForTimes

func (mr *MockProducerMockRecorder) OffsetsForTimes(times, timeoutMs interface{}) *gomock.Call

OffsetsForTimes indicates an expected call of OffsetsForTimes

func (*MockProducerMockRecorder) Produce

func (mr *MockProducerMockRecorder) Produce(msg, deliveryChan interface{}) *gomock.Call

Produce indicates an expected call of Produce

func (*MockProducerMockRecorder) ProduceChannel

func (mr *MockProducerMockRecorder) ProduceChannel() *gomock.Call

ProduceChannel indicates an expected call of ProduceChannel

func (*MockProducerMockRecorder) QueryWatermarkOffsets

func (mr *MockProducerMockRecorder) QueryWatermarkOffsets(topic, partition, timeoutMs interface{}) *gomock.Call

QueryWatermarkOffsets indicates an expected call of QueryWatermarkOffsets

func (*MockProducerMockRecorder) SetOAuthBearerToken

func (mr *MockProducerMockRecorder) SetOAuthBearerToken(oauthBearerToken interface{}) *gomock.Call

SetOAuthBearerToken indicates an expected call of SetOAuthBearerToken

func (*MockProducerMockRecorder) SetOAuthBearerTokenFailure

func (mr *MockProducerMockRecorder) SetOAuthBearerTokenFailure(errstr interface{}) *gomock.Call

SetOAuthBearerTokenFailure indicates an expected call of SetOAuthBearerTokenFailure

func (*MockProducerMockRecorder) String

func (mr *MockProducerMockRecorder) String() *gomock.Call

String indicates an expected call of String

func (*MockProducerMockRecorder) TestFatalError

func (mr *MockProducerMockRecorder) TestFatalError(code, str interface{}) *gomock.Call

TestFatalError indicates an expected call of TestFatalError

type MockProducerServiceInterface

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

MockProducerServiceInterface is a mock of ProducerServiceInterface interface

func NewMockProducerServiceInterface

func NewMockProducerServiceInterface(ctrl *gomock.Controller) *MockProducerServiceInterface

NewMockProducerServiceInterface creates a new mock instance

func (*MockProducerServiceInterface) EXPECT

EXPECT returns an object that allows the caller to indicate expected use

func (*MockProducerServiceInterface) GetProducerInstance

func (m *MockProducerServiceInterface) GetProducerInstance() kafkacommon.Producer

GetProducerInstance mocks base method

func (*MockProducerServiceInterface) ProduceEvent

func (m *MockProducerServiceInterface) ProduceEvent(requestedTopic, recordKey string, event models.CRCCloudEvent) error

ProduceEvent mocks base method

type MockProducerServiceInterfaceMockRecorder

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

MockProducerServiceInterfaceMockRecorder is the mock recorder for MockProducerServiceInterface

func (*MockProducerServiceInterfaceMockRecorder) GetProducerInstance

func (mr *MockProducerServiceInterfaceMockRecorder) GetProducerInstance() *gomock.Call

GetProducerInstance indicates an expected call of GetProducerInstance

func (*MockProducerServiceInterfaceMockRecorder) ProduceEvent

func (mr *MockProducerServiceInterfaceMockRecorder) ProduceEvent(requestedTopic, recordKey, event interface{}) *gomock.Call

ProduceEvent indicates an expected call of ProduceEvent

type MockTopicServiceInterface

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

MockTopicServiceInterface is a mock of TopicServiceInterface interface

func NewMockTopicServiceInterface

func NewMockTopicServiceInterface(ctrl *gomock.Controller) *MockTopicServiceInterface

NewMockTopicServiceInterface creates a new mock instance

func (*MockTopicServiceInterface) EXPECT

EXPECT returns an object that allows the caller to indicate expected use

func (*MockTopicServiceInterface) GetTopic

func (m *MockTopicServiceInterface) GetTopic(requested string) (string, error)

GetTopic mocks base method

type MockTopicServiceInterfaceMockRecorder

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

MockTopicServiceInterfaceMockRecorder is the mock recorder for MockTopicServiceInterface

func (*MockTopicServiceInterfaceMockRecorder) GetTopic

func (mr *MockTopicServiceInterfaceMockRecorder) GetTopic(requested interface{}) *gomock.Call

GetTopic indicates an expected call of GetTopic

Jump to

Keyboard shortcuts

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