 Documentation
      ¶
      Documentation
      ¶
    
    
  
    
  
    Overview ¶
Package scheduler includes the interfaces for the mesos scheduler and the mesos executor driver. It also contains as well as an implementation of the driver that you can use in your code.
Index ¶
- type CredentialHandler
- type DriverConfig
- type ErrDriverAborted
- type MesosSchedulerDriver
- func (driver *MesosSchedulerDriver) Abort() (stat mesos.Status, err error)
- func (driver *MesosSchedulerDriver) Connected() bool
- func (driver *MesosSchedulerDriver) DeclineOffer(offerId *mesos.OfferID, filters *mesos.Filters) (mesos.Status, error)
- func (driver *MesosSchedulerDriver) Join() (mesos.Status, error)
- func (driver *MesosSchedulerDriver) KillTask(taskId *mesos.TaskID) (mesos.Status, error)
- func (driver *MesosSchedulerDriver) LaunchTasks(offerIds []*mesos.OfferID, tasks []*mesos.TaskInfo, filters *mesos.Filters) (mesos.Status, error)
- func (driver *MesosSchedulerDriver) ReconcileTasks(statuses []*mesos.TaskStatus) (mesos.Status, error)
- func (driver *MesosSchedulerDriver) RequestResources(requests []*mesos.Request) (mesos.Status, error)
- func (driver *MesosSchedulerDriver) ReviveOffers() (mesos.Status, error)
- func (driver *MesosSchedulerDriver) Run() (mesos.Status, error)
- func (driver *MesosSchedulerDriver) Running() bool
- func (driver *MesosSchedulerDriver) SendFrameworkMessage(executorId *mesos.ExecutorID, slaveId *mesos.SlaveID, data string) (mesos.Status, error)
- func (driver *MesosSchedulerDriver) Start() (mesos.Status, error)
- func (driver *MesosSchedulerDriver) Status() mesos.Status
- func (driver *MesosSchedulerDriver) Stop(failover bool) (mesos.Status, error)
 
- type MockScheduler
- func (sched *MockScheduler) Disconnected(SchedulerDriver)
- func (sched *MockScheduler) Error(d SchedulerDriver, msg string)
- func (sched *MockScheduler) ExecutorLost(SchedulerDriver, *mesos.ExecutorID, *mesos.SlaveID, int)
- func (sched *MockScheduler) FrameworkMessage(SchedulerDriver, *mesos.ExecutorID, *mesos.SlaveID, string)
- func (sched *MockScheduler) OfferRescinded(SchedulerDriver, *mesos.OfferID)
- func (sched *MockScheduler) Registered(SchedulerDriver, *mesos.FrameworkID, *mesos.MasterInfo)
- func (sched *MockScheduler) Reregistered(SchedulerDriver, *mesos.MasterInfo)
- func (sched *MockScheduler) ResourceOffers(SchedulerDriver, []*mesos.Offer)
- func (sched *MockScheduler) SlaveLost(SchedulerDriver, *mesos.SlaveID)
- func (sched *MockScheduler) StatusUpdate(SchedulerDriver, *mesos.TaskStatus)
 
- type Scheduler
- type SchedulerDriver
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type CredentialHandler ¶
type CredentialHandler struct {
	// contains filtered or unexported fields
}
    type DriverConfig ¶
type DriverConfig struct {
	Scheduler        Scheduler
	Framework        *mesos.FrameworkInfo
	Master           string
	Credential       *mesos.Credential                     // optional
	WithAuthContext  func(context.Context) context.Context // required when Credential != nil
	HostnameOverride string                                // optional
	BindingAddress   net.IP                                // optional
	BindingPort      uint16                                // optional
	PublishedAddress net.IP                                // optional
	NewMessenger     func() (messenger.Messenger, error)   // optional
	NewDetector      func() (detector.Master, error)       // optional
}
    type ErrDriverAborted ¶ added in v1.2.3
type ErrDriverAborted struct {
	Reason string
}
    func (*ErrDriverAborted) Error ¶ added in v1.2.3
func (err *ErrDriverAborted) Error() string
type MesosSchedulerDriver ¶
type MesosSchedulerDriver struct {
	// contains filtered or unexported fields
}
    Concrete implementation of a SchedulerDriver that connects a Scheduler with a Mesos master. The MesosSchedulerDriver is thread-safe.
Note that scheduler failover is supported in Mesos. After a scheduler is registered with Mesos it may failover (to a new process on the same machine or across multiple machines) by creating a new driver with the ID given to it in Scheduler.Registered().
The driver is responsible for invoking the Scheduler callbacks as it communicates with the Mesos master.
Note that blocking on the MesosSchedulerDriver (e.g., via MesosSchedulerDriver.Join) doesn't affect the scheduler callbacks in anyway because they are handled by a different thread.
TODO(yifan): examples. See src/examples/test_framework.cpp for an example of using the MesosSchedulerDriver.
func NewMesosSchedulerDriver ¶
func NewMesosSchedulerDriver(config DriverConfig) (initializedDriver *MesosSchedulerDriver, err error)
Create a new mesos scheduler driver with the given scheduler, framework info, master address, and credential(optional)
func (*MesosSchedulerDriver) Abort ¶
func (driver *MesosSchedulerDriver) Abort() (stat mesos.Status, err error)
func (*MesosSchedulerDriver) Connected ¶
func (driver *MesosSchedulerDriver) Connected() bool
Connected returns true if the driver has a registered (and authenticated, if enabled) connection to the leading mesos master
func (*MesosSchedulerDriver) DeclineOffer ¶
func (*MesosSchedulerDriver) Join ¶
func (driver *MesosSchedulerDriver) Join() (mesos.Status, error)
Join blocks until the driver is stopped. Should follow a call to Start()
func (*MesosSchedulerDriver) LaunchTasks ¶
func (*MesosSchedulerDriver) ReconcileTasks ¶
func (driver *MesosSchedulerDriver) ReconcileTasks(statuses []*mesos.TaskStatus) (mesos.Status, error)
func (*MesosSchedulerDriver) RequestResources ¶
func (*MesosSchedulerDriver) ReviveOffers ¶
func (driver *MesosSchedulerDriver) ReviveOffers() (mesos.Status, error)
func (*MesosSchedulerDriver) Run ¶
func (driver *MesosSchedulerDriver) Run() (mesos.Status, error)
Run starts and joins driver process and waits to be stopped or aborted.
func (*MesosSchedulerDriver) Running ¶ added in v1.2.3
func (driver *MesosSchedulerDriver) Running() bool
Running returns true if the driver is in the DRIVER_RUNNING state
func (*MesosSchedulerDriver) SendFrameworkMessage ¶
func (driver *MesosSchedulerDriver) SendFrameworkMessage(executorId *mesos.ExecutorID, slaveId *mesos.SlaveID, data string) (mesos.Status, error)
func (*MesosSchedulerDriver) Start ¶
func (driver *MesosSchedulerDriver) Start() (mesos.Status, error)
Starts the scheduler driver. Returns immediately if an error occurs within start sequence.
func (*MesosSchedulerDriver) Status ¶
func (driver *MesosSchedulerDriver) Status() mesos.Status
Status returns the current driver status
type MockScheduler ¶
func NewMockScheduler ¶
func NewMockScheduler() *MockScheduler
func (*MockScheduler) Disconnected ¶
func (sched *MockScheduler) Disconnected(SchedulerDriver)
func (*MockScheduler) Error ¶
func (sched *MockScheduler) Error(d SchedulerDriver, msg string)
func (*MockScheduler) ExecutorLost ¶
func (sched *MockScheduler) ExecutorLost(SchedulerDriver, *mesos.ExecutorID, *mesos.SlaveID, int)
func (*MockScheduler) FrameworkMessage ¶
func (sched *MockScheduler) FrameworkMessage(SchedulerDriver, *mesos.ExecutorID, *mesos.SlaveID, string)
func (*MockScheduler) OfferRescinded ¶
func (sched *MockScheduler) OfferRescinded(SchedulerDriver, *mesos.OfferID)
func (*MockScheduler) Registered ¶
func (sched *MockScheduler) Registered(SchedulerDriver, *mesos.FrameworkID, *mesos.MasterInfo)
func (*MockScheduler) Reregistered ¶
func (sched *MockScheduler) Reregistered(SchedulerDriver, *mesos.MasterInfo)
func (*MockScheduler) ResourceOffers ¶
func (sched *MockScheduler) ResourceOffers(SchedulerDriver, []*mesos.Offer)
func (*MockScheduler) SlaveLost ¶
func (sched *MockScheduler) SlaveLost(SchedulerDriver, *mesos.SlaveID)
func (*MockScheduler) StatusUpdate ¶
func (sched *MockScheduler) StatusUpdate(SchedulerDriver, *mesos.TaskStatus)
type Scheduler ¶
type Scheduler interface {
	// Invoked when the scheduler successfully registers with a Mesos
	// master. A unique ID (generated by the master) used for
	// distinguishing this framework from others and MasterInfo
	// with the ip and port of the current master are provided as arguments.
	Registered(SchedulerDriver, *mesos.FrameworkID, *mesos.MasterInfo)
	// Invoked when the scheduler re-registers with a newly elected Mesos master.
	// This is only called when the scheduler has previously been registered.
	// MasterInfo containing the updated information about the elected master
	// is provided as an argument.
	Reregistered(SchedulerDriver, *mesos.MasterInfo)
	// Invoked when the scheduler becomes "disconnected" from the master
	// (e.g., the master fails and another is taking over).
	Disconnected(SchedulerDriver)
	// Invoked when resources have been offered to this framework. A
	// single offer will only contain resources from a single slave.
	// Resources associated with an offer will not be re-offered to
	// _this_ framework until either (a) this framework has rejected
	// those resources (see SchedulerDriver::launchTasks) or (b) those
	// resources have been rescinded (see Scheduler::offerRescinded).
	// Note that resources may be concurrently offered to more than one
	// framework at a time (depending on the allocator being used). In
	// that case, the first framework to launch tasks using those
	// resources will be able to use them while the other frameworks
	// will have those resources rescinded (or if a framework has
	// already launched tasks with those resources then those tasks will
	// fail with a TASK_LOST status and a message saying as much).
	ResourceOffers(SchedulerDriver, []*mesos.Offer)
	// Invoked when an offer is no longer valid (e.g., the slave was
	// lost or another framework used resources in the offer). If for
	// whatever reason an offer is never rescinded (e.g., dropped
	// message, failing over framework, etc.), a framwork that attempts
	// to launch tasks using an invalid offer will receive TASK_LOST
	// status updates for those tasks (see Scheduler::resourceOffers).
	OfferRescinded(SchedulerDriver, *mesos.OfferID)
	// Invoked when the status of a task has changed (e.g., a slave is
	// lost and so the task is lost, a task finishes and an executor
	// sends a status update saying so, etc). Note that returning from
	// this callback _acknowledges_ receipt of this status update! If
	// for whatever reason the scheduler aborts during this callback (or
	// the process exits) another status update will be delivered (note,
	// however, that this is currently not true if the slave sending the
	// status update is lost/fails during that time).
	StatusUpdate(SchedulerDriver, *mesos.TaskStatus)
	// Invoked when an executor sends a message. These messages are best
	// effort; do not expect a framework message to be retransmitted in
	// any reliable fashion.
	FrameworkMessage(SchedulerDriver, *mesos.ExecutorID, *mesos.SlaveID, string)
	// Invoked when a slave has been determined unreachable (e.g.,
	// machine failure, network partition). Most frameworks will need to
	// reschedule any tasks launched on this slave on a new slave.
	SlaveLost(SchedulerDriver, *mesos.SlaveID)
	// Invoked when an executor has exited/terminated. Note that any
	// tasks running will have TASK_LOST status updates automagically
	// generated.
	ExecutorLost(SchedulerDriver, *mesos.ExecutorID, *mesos.SlaveID, int)
	// Invoked when there is an unrecoverable error in the scheduler or
	// scheduler driver. The driver will be aborted BEFORE invoking this
	// callback.
	Error(SchedulerDriver, string)
}
    Scheduler a type with callback attributes to be provided by frameworks schedulers.
Each callback includes a reference to the scheduler driver that was used to run this scheduler. The pointer will not change for the duration of a scheduler (i.e., from the point you do SchedulerDriver.Start() to the point that SchedulerDriver.Stop() returns). This is intended for convenience so that a scheduler doesn't need to store a reference to the driver itself.
type SchedulerDriver ¶
type SchedulerDriver interface {
	// Starts the scheduler driver. This needs to be called before any
	// other driver calls are made.
	Start() (mesos.Status, error)
	// Stops the scheduler driver. If the 'failover' flag is set to
	// false then it is expected that this framework will never
	// reconnect to Mesos and all of its executors and tasks can be
	// terminated. Otherwise, all executors and tasks will remain
	// running (for some framework specific failover timeout) allowing the
	// scheduler to reconnect (possibly in the same process, or from a
	// different process, for example, on a different machine).
	Stop(failover bool) (mesos.Status, error)
	// Aborts the driver so that no more callbacks can be made to the
	// scheduler. The semantics of abort and stop have deliberately been
	// separated so that code can detect an aborted driver (i.e., via
	// the return status of SchedulerDriver::join, see below), and
	// instantiate and start another driver if desired (from within the
	// same process). Note that 'Stop()' is not automatically called
	// inside 'Abort()'.
	Abort() (mesos.Status, error)
	// Waits for the driver to be stopped or aborted, possibly
	// _blocking_ the current thread indefinitely. The return status of
	// this function can be used to determine if the driver was aborted
	// (see mesos.proto for a description of Status).
	Join() (mesos.Status, error)
	// Starts and immediately joins (i.e., blocks on) the driver.
	Run() (mesos.Status, error)
	// Requests resources from Mesos (see mesos.proto for a description
	// of Request and how, for example, to request resources
	// from specific slaves). Any resources available are offered to the
	// framework via Scheduler.ResourceOffers callback, asynchronously.
	RequestResources(requests []*mesos.Request) (mesos.Status, error)
	// Launches the given set of tasks. Any resources remaining (i.e.,
	// not used by the tasks or their executors) will be considered
	// declined. The specified filters are applied on all unused
	// resources (see mesos.proto for a description of Filters).
	// Available resources are aggregated when mutiple offers are
	// provided. Note that all offers must belong to the same slave.
	// Invoking this function with an empty collection of tasks declines
	// offers in their entirety (see Scheduler::declineOffer).
	LaunchTasks(offerIDs []*mesos.OfferID, tasks []*mesos.TaskInfo, filters *mesos.Filters) (mesos.Status, error)
	// Kills the specified task. Note that attempting to kill a task is
	// currently not reliable. If, for example, a scheduler fails over
	// while it was attempting to kill a task it will need to retry in
	// the future. Likewise, if unregistered / disconnected, the request
	// will be dropped (these semantics may be changed in the future).
	KillTask(taskID *mesos.TaskID) (mesos.Status, error)
	// Declines an offer in its entirety and applies the specified
	// filters on the resources (see mesos.proto for a description of
	// Filters). Note that this can be done at any time, it is not
	// necessary to do this within the Scheduler::resourceOffers
	// callback.
	DeclineOffer(offerID *mesos.OfferID, filters *mesos.Filters) (mesos.Status, error)
	// Removes all filters previously set by the framework (via
	// LaunchTasks()). This enables the framework to receive offers from
	// those filtered slaves.
	ReviveOffers() (mesos.Status, error)
	// Sends a message from the framework to one of its executors. These
	// messages are best effort; do not expect a framework message to be
	// retransmitted in any reliable fashion.
	SendFrameworkMessage(executorID *mesos.ExecutorID, slaveID *mesos.SlaveID, data string) (mesos.Status, error)
	// Allows the framework to query the status for non-terminal tasks.
	// This causes the master to send back the latest task status for
	// each task in 'statuses', if possible. Tasks that are no longer
	// known will result in a TASK_LOST update. If statuses is empty,
	// then the master will send the latest status for each task
	// currently known.
	ReconcileTasks(statuses []*mesos.TaskStatus) (mesos.Status, error)
}
    Interface for connecting a scheduler to Mesos. This interface is used both to manage the scheduler's lifecycle (start it, stop it, or wait for it to finish) and to interact with Mesos (e.g., launch tasks, kill tasks, etc.). See the MesosSchedulerDriver type for a concrete impl of a SchedulerDriver.